From ad9df1099919c3e02541a8206419417cb1edebc2 Mon Sep 17 00:00:00 2001 From: Dmitry Khalanskiy Date: Thu, 18 Jan 2024 15:20:38 +0100 Subject: [PATCH 1/3] Update the copyright notices to the new requirements * Remove copyright notices from individual files; * Update the NOTICE file to include the year of initial publication and the year of the latest change; * Remove the IDEA template for adding notices to every file. --- .idea/copyright/kotlinx_coroutines.xml | 6 ------ LICENSE.txt | 2 +- benchmarks/build.gradle.kts | 4 ---- .../java/benchmarks/flow/scrabble/RxJava2PlaysScrabble.java | 4 ---- .../benchmarks/flow/scrabble/RxJava2PlaysScrabbleOpt.java | 4 ---- .../flow/scrabble/optimizations/FlowableCharSequence.java | 4 ---- .../flow/scrabble/optimizations/FlowableSplit.java | 4 ---- .../flow/scrabble/optimizations/StringFlowable.java | 4 ---- .../src/jmh/kotlin/benchmarks/ChannelSinkBenchmark.kt | 4 ---- .../src/jmh/kotlin/benchmarks/ChannelSinkDepthBenchmark.kt | 4 ---- .../kotlin/benchmarks/ChannelSinkNoAllocationsBenchmark.kt | 4 ---- .../src/jmh/kotlin/benchmarks/ParametrizedDispatcherBase.kt | 4 ---- .../jmh/kotlin/benchmarks/SequentialSemaphoreBenchmark.kt | 4 ---- .../src/jmh/kotlin/benchmarks/akka/PingPongAkkaBenchmark.kt | 4 ---- .../kotlin/benchmarks/akka/StatefulActorAkkaBenchmark.kt | 4 ---- .../benchmarks/debug/DebugSequenceOverheadBenchmark.kt | 4 ---- .../src/jmh/kotlin/benchmarks/flow/CombineFlowsBenchmark.kt | 4 ---- .../jmh/kotlin/benchmarks/flow/CombineTwoFlowsBenchmark.kt | 4 ---- .../src/jmh/kotlin/benchmarks/flow/FlatMapMergeBenchmark.kt | 4 ---- .../jmh/kotlin/benchmarks/flow/FlowFlattenMergeBenchmark.kt | 4 ---- .../src/jmh/kotlin/benchmarks/flow/NumbersBenchmark.kt | 5 ----- .../src/jmh/kotlin/benchmarks/flow/SafeFlowBenchmark.kt | 4 ---- benchmarks/src/jmh/kotlin/benchmarks/flow/TakeBenchmark.kt | 4 ---- .../benchmarks/flow/scrabble/FlowPlaysScrabbleBase.kt | 4 ---- .../kotlin/benchmarks/flow/scrabble/FlowPlaysScrabbleOpt.kt | 4 ---- .../kotlin/benchmarks/flow/scrabble/IterableSpliterator.kt | 4 ---- .../kotlin/benchmarks/flow/scrabble/ReactorPlaysScrabble.kt | 4 ---- .../benchmarks/flow/scrabble/SaneFlowPlaysScrabble.kt | 4 ---- .../benchmarks/flow/scrabble/SequencePlaysScrabble.kt | 4 ---- .../benchmarks/flow/scrabble/ShakespearePlaysScrabble.kt | 4 ---- .../scheduler/DispatchersContextSwitchBenchmark.kt | 4 ---- .../jmh/kotlin/benchmarks/scheduler/ForkJoinBenchmark.kt | 4 ---- .../src/jmh/kotlin/benchmarks/scheduler/LaunchBenchmark.kt | 4 ---- .../kotlin/benchmarks/scheduler/StatefulAwaitsBenchmark.kt | 4 ---- .../scheduler/actors/ConcurrentStatefulActorBenchmark.kt | 4 ---- .../benchmarks/scheduler/actors/CycledActorsBenchmark.kt | 4 ---- .../benchmarks/scheduler/actors/PingPongActorBenchmark.kt | 4 ---- .../scheduler/actors/PingPongWithBlockingContext.kt | 4 ---- .../benchmarks/scheduler/actors/StatefulActorBenchmark.kt | 4 ---- .../src/main/kotlin/benchmarks/common/BenchmarkUtils.kt | 4 ---- build.gradle | 4 ---- buildSrc/build.gradle.kts | 4 ---- buildSrc/settings.gradle.kts | 3 --- buildSrc/src/main/kotlin/CacheRedirector.kt | 4 ---- buildSrc/src/main/kotlin/CommunityProjectsBuild.kt | 3 --- buildSrc/src/main/kotlin/Dokka.kt | 4 ---- buildSrc/src/main/kotlin/Idea.kt | 4 ---- buildSrc/src/main/kotlin/Java9Modularity.kt | 4 ---- buildSrc/src/main/kotlin/OptInPreset.kt | 3 --- buildSrc/src/main/kotlin/Platform.kt | 4 ---- buildSrc/src/main/kotlin/Projects.kt | 3 --- buildSrc/src/main/kotlin/Publishing.kt | 4 ---- buildSrc/src/main/kotlin/SourceSets.kt | 3 --- buildSrc/src/main/kotlin/UnpackAar.kt | 4 ---- buildSrc/src/main/kotlin/VersionFile.kt | 4 ---- .../src/main/kotlin/animalsniffer-conventions.gradle.kts | 4 ---- buildSrc/src/main/kotlin/bom-conventions.gradle.kts | 3 --- .../kotlin/configure-compilation-conventions.gradle.kts | 4 ---- buildSrc/src/main/kotlin/dokka-conventions.gradle.kts | 4 ---- .../src/main/kotlin/java-modularity-conventions.gradle.kts | 4 ---- buildSrc/src/main/kotlin/knit-conventions.gradle.kts | 4 ---- buildSrc/src/main/kotlin/kotlin-jvm-conventions.gradle.kts | 4 ---- .../main/kotlin/kotlin-multiplatform-conventions.gradle.kts | 4 ---- buildSrc/src/main/kotlin/kover-conventions.gradle.kts | 3 --- buildSrc/src/main/kotlin/pub-conventions.gradle.kts | 4 ---- buildSrc/src/main/kotlin/source-set-conventions.gradle.kts | 3 --- docs/knit.code.include | 4 ---- docs/knit.test.template | 4 ---- docs/topics/knit.properties | 4 ---- gradle.properties | 4 ---- integration-testing/build.gradle | 5 ----- .../smokeTest/src/commonTest/kotlin/SampleTest.kt | 4 ---- .../src/coreAgentTest/kotlin/CoreAgentTest.kt | 3 --- .../src/debugAgentTest/kotlin/DebugAgentTest.kt | 3 --- .../src/debugAgentTest/kotlin/DebugProbes.kt | 3 --- .../src/debugAgentTest/kotlin/PrecompiledDebugProbesTest.kt | 3 --- .../debugDynamicAgentTest/kotlin/DynamicAttachDebugTest.kt | 3 --- .../src/jvmCoreTest/kotlin/Jdk8InCoreIntegration.kt | 3 --- .../kotlin/ListAllCoroutineThrowableSubclassesTest.kt | 4 ---- .../mavenTest/kotlin/MavenPublicationAtomicfuValidator.kt | 4 ---- .../mavenTest/kotlin/MavenPublicationMetaInfValidator.kt | 4 ---- .../mavenTest/kotlin/MavenPublicationVersionValidator.kt | 4 ---- integration/kotlinx-coroutines-guava/build.gradle.kts | 4 ---- .../kotlinx-coroutines-guava/src/ListenableFuture.kt | 4 ---- .../FutureAsDeferredUnhandledCompletionExceptionTest.kt | 4 ---- .../test/ListenableFutureExceptionsTest.kt | 4 ---- .../kotlinx-coroutines-guava/test/ListenableFutureTest.kt | 4 ---- .../test/ListenableFutureToStringTest.kt | 4 ---- integration/kotlinx-coroutines-jdk8/build.gradle.kts | 4 ---- .../kotlinx-coroutines-play-services/build.gradle.kts | 4 ---- integration/kotlinx-coroutines-play-services/src/Tasks.kt | 4 ---- .../kotlinx-coroutines-play-services/test/TaskTest.kt | 4 ---- integration/kotlinx-coroutines-slf4j/build.gradle.kts | 4 ---- integration/kotlinx-coroutines-slf4j/src/MDCContext.kt | 4 ---- integration/kotlinx-coroutines-slf4j/test/MDCContextTest.kt | 4 ---- knit.properties | 4 ---- kotlinx-coroutines-bom/build.gradle | 3 --- kotlinx-coroutines-core/build.gradle | 4 ---- kotlinx-coroutines-core/common/src/AbstractCoroutine.kt | 3 --- kotlinx-coroutines-core/common/src/Annotations.kt | 4 ---- kotlinx-coroutines-core/common/src/Await.kt | 4 ---- kotlinx-coroutines-core/common/src/Builders.common.kt | 4 ---- .../common/src/CancellableContinuation.kt | 4 ---- .../common/src/CancellableContinuationImpl.kt | 4 ---- .../common/src/CloseableCoroutineDispatcher.kt | 4 ---- kotlinx-coroutines-core/common/src/CompletableDeferred.kt | 3 --- kotlinx-coroutines-core/common/src/CompletableJob.kt | 4 ---- .../common/src/CompletionHandler.common.kt | 4 ---- kotlinx-coroutines-core/common/src/CompletionState.kt | 4 ---- .../common/src/CoroutineContext.common.kt | 4 ---- kotlinx-coroutines-core/common/src/CoroutineDispatcher.kt | 4 ---- .../common/src/CoroutineExceptionHandler.kt | 4 ---- kotlinx-coroutines-core/common/src/CoroutineName.kt | 4 ---- kotlinx-coroutines-core/common/src/CoroutineScope.kt | 3 --- kotlinx-coroutines-core/common/src/CoroutineStart.kt | 3 --- kotlinx-coroutines-core/common/src/Debug.common.kt | 4 ---- kotlinx-coroutines-core/common/src/Deferred.kt | 4 ---- kotlinx-coroutines-core/common/src/Delay.kt | 4 ---- kotlinx-coroutines-core/common/src/Dispatchers.common.kt | 4 ---- kotlinx-coroutines-core/common/src/EventLoop.common.kt | 4 ---- kotlinx-coroutines-core/common/src/Exceptions.common.kt | 4 ---- kotlinx-coroutines-core/common/src/Job.kt | 4 ---- kotlinx-coroutines-core/common/src/JobSupport.kt | 3 --- .../common/src/MainCoroutineDispatcher.kt | 4 ---- kotlinx-coroutines-core/common/src/NonCancellable.kt | 3 --- kotlinx-coroutines-core/common/src/Runnable.common.kt | 4 ---- kotlinx-coroutines-core/common/src/SchedulerTask.common.kt | 4 ---- kotlinx-coroutines-core/common/src/Supervisor.kt | 3 --- kotlinx-coroutines-core/common/src/Timeout.kt | 3 --- kotlinx-coroutines-core/common/src/Unconfined.kt | 4 ---- kotlinx-coroutines-core/common/src/Waiter.kt | 4 ---- kotlinx-coroutines-core/common/src/Yield.kt | 4 ---- kotlinx-coroutines-core/common/src/channels/Broadcast.kt | 4 ---- .../common/src/channels/BroadcastChannel.kt | 4 ---- .../common/src/channels/BufferOverflow.kt | 4 ---- kotlinx-coroutines-core/common/src/channels/Channel.kt | 4 ---- .../common/src/channels/ChannelCoroutine.kt | 4 ---- .../common/src/channels/Channels.common.kt | 3 --- .../common/src/channels/ConflatedBufferedChannel.kt | 4 ---- kotlinx-coroutines-core/common/src/channels/Deprecated.kt | 3 --- kotlinx-coroutines-core/common/src/channels/Produce.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/Builders.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/Channels.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/Flow.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/FlowCollector.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/Migration.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/SharedFlow.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/SharingStarted.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/StateFlow.kt | 4 ---- .../common/src/flow/internal/AbstractSharedFlow.kt | 4 ---- .../common/src/flow/internal/ChannelFlow.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/internal/Combine.kt | 3 --- .../common/src/flow/internal/FlowCoroutine.kt | 4 ---- .../common/src/flow/internal/FlowExceptions.common.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/internal/Merge.kt | 4 ---- .../common/src/flow/internal/NopCollector.kt | 4 ---- .../common/src/flow/internal/NullSurrogate.kt | 4 ---- .../common/src/flow/internal/SafeCollector.common.kt | 4 ---- .../common/src/flow/internal/SendingCollector.kt | 4 ---- .../common/src/flow/operators/Context.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/operators/Delay.kt | 4 ---- .../common/src/flow/operators/Distinct.kt | 4 ---- .../common/src/flow/operators/Emitters.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/operators/Errors.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/operators/Limit.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/operators/Lint.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/operators/Merge.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/operators/Share.kt | 4 ---- .../common/src/flow/operators/Transform.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/operators/Zip.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/terminal/Collect.kt | 4 ---- .../common/src/flow/terminal/Collection.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/terminal/Count.kt | 4 ---- kotlinx-coroutines-core/common/src/flow/terminal/Reduce.kt | 4 ---- kotlinx-coroutines-core/common/src/internal/Atomic.kt | 3 --- .../common/src/internal/Concurrent.common.kt | 4 ---- .../common/src/internal/ConcurrentLinkedList.kt | 4 ---- .../src/internal/CoroutineExceptionHandlerImpl.common.kt | 4 ---- .../common/src/internal/DispatchedContinuation.kt | 4 ---- .../common/src/internal/DispatchedTask.kt | 4 ---- kotlinx-coroutines-core/common/src/internal/InlineList.kt | 4 ---- .../common/src/internal/InternalAnnotations.common.kt | 4 ---- .../common/src/internal/LimitedDispatcher.kt | 4 ---- .../common/src/internal/LocalAtomics.common.kt | 4 ---- .../common/src/internal/LockFreeLinkedList.common.kt | 3 --- .../common/src/internal/LockFreeTaskQueue.kt | 4 ---- .../common/src/internal/MainDispatcherFactory.kt | 4 ---- .../common/src/internal/OnUndeliveredElement.kt | 4 ---- .../common/src/internal/ProbesSupport.common.kt | 4 ---- kotlinx-coroutines-core/common/src/internal/Scopes.kt | 4 ---- .../common/src/internal/StackTraceRecovery.common.kt | 4 ---- kotlinx-coroutines-core/common/src/internal/Symbol.kt | 4 ---- .../common/src/internal/Synchronized.common.kt | 4 ---- .../common/src/internal/SystemProps.common.kt | 4 ---- .../common/src/internal/ThreadContext.common.kt | 4 ---- .../common/src/internal/ThreadLocal.common.kt | 4 ---- .../common/src/internal/ThreadSafeHeap.kt | 4 ---- .../common/src/intrinsics/Cancellable.kt | 4 ---- .../common/src/intrinsics/Undispatched.kt | 4 ---- kotlinx-coroutines-core/common/src/selects/OnTimeout.kt | 4 ---- kotlinx-coroutines-core/common/src/selects/Select.kt | 4 ---- kotlinx-coroutines-core/common/src/selects/SelectOld.kt | 4 ---- .../common/src/selects/SelectUnbiased.kt | 3 --- kotlinx-coroutines-core/common/src/selects/WhileSelect.kt | 4 ---- kotlinx-coroutines-core/common/src/sync/Mutex.kt | 4 ---- kotlinx-coroutines-core/common/src/sync/Semaphore.kt | 4 ---- .../common/test/AbstractCoroutineTest.kt | 4 ---- kotlinx-coroutines-core/common/test/AsyncLazyTest.kt | 4 ---- kotlinx-coroutines-core/common/test/AsyncTest.kt | 4 ---- .../common/test/AtomicCancellationCommonTest.kt | 4 ---- .../common/test/AwaitCancellationTest.kt | 4 ---- kotlinx-coroutines-core/common/test/AwaitTest.kt | 4 ---- kotlinx-coroutines-core/common/test/BuilderContractsTest.kt | 4 ---- .../common/test/CancellableContinuationHandlersTest.kt | 4 ---- .../common/test/CancellableContinuationTest.kt | 3 --- .../common/test/CancellableResumeTest.kt | 4 ---- .../common/test/CancelledParentAttachTest.kt | 4 ---- .../common/test/CompletableDeferredTest.kt | 4 ---- kotlinx-coroutines-core/common/test/CompletableJobTest.kt | 4 ---- .../common/test/CoroutineDispatcherOperatorFunInvokeTest.kt | 4 ---- .../common/test/CoroutineExceptionHandlerTest.kt | 4 ---- kotlinx-coroutines-core/common/test/CoroutineScopeTest.kt | 4 ---- kotlinx-coroutines-core/common/test/CoroutinesTest.kt | 4 ---- kotlinx-coroutines-core/common/test/DelayDurationTest.kt | 4 ---- kotlinx-coroutines-core/common/test/DelayTest.kt | 4 ---- .../common/test/DispatchedContinuationTest.kt | 4 ---- kotlinx-coroutines-core/common/test/DurationToMillisTest.kt | 3 --- kotlinx-coroutines-core/common/test/EmptyContext.kt | 4 ---- .../common/test/ExperimentalDispatchModeTest.kt | 4 ---- kotlinx-coroutines-core/common/test/FailedJobTest.kt | 4 ---- kotlinx-coroutines-core/common/test/ImmediateYieldTest.kt | 4 ---- kotlinx-coroutines-core/common/test/JobExtensionsTest.kt | 4 ---- kotlinx-coroutines-core/common/test/JobStatesTest.kt | 4 ---- kotlinx-coroutines-core/common/test/JobTest.kt | 4 ---- kotlinx-coroutines-core/common/test/LaunchLazyTest.kt | 4 ---- .../common/test/LimitedParallelismSharedTest.kt | 4 ---- .../common/test/MainDispatcherTestBase.kt | 4 ---- kotlinx-coroutines-core/common/test/NonCancellableTest.kt | 4 ---- .../common/test/ParentCancellationTest.kt | 4 ---- kotlinx-coroutines-core/common/test/SupervisorTest.kt | 4 ---- kotlinx-coroutines-core/common/test/TestBase.common.kt | 4 ---- kotlinx-coroutines-core/common/test/UnconfinedTest.kt | 4 ---- .../common/test/UndispatchedResultTest.kt | 4 ---- kotlinx-coroutines-core/common/test/WithContextTest.kt | 4 ---- .../common/test/WithTimeoutDurationTest.kt | 4 ---- .../common/test/WithTimeoutOrNullDurationTest.kt | 4 ---- .../common/test/WithTimeoutOrNullTest.kt | 4 ---- kotlinx-coroutines-core/common/test/WithTimeoutTest.kt | 4 ---- .../common/test/channels/BasicOperationsTest.kt | 4 ---- .../common/test/channels/BroadcastChannelFactoryTest.kt | 4 ---- .../common/test/channels/BroadcastTest.kt | 4 ---- .../common/test/channels/BufferedBroadcastChannelTest.kt | 4 ---- .../common/test/channels/BufferedChannelTest.kt | 4 ---- .../common/test/channels/ChannelBufferOverflowTest.kt | 4 ---- .../common/test/channels/ChannelFactoryTest.kt | 4 ---- .../common/test/channels/ChannelReceiveCatchingTest.kt | 4 ---- .../test/channels/ChannelUndeliveredElementFailureTest.kt | 4 ---- .../common/test/channels/ChannelUndeliveredElementTest.kt | 4 ---- .../common/test/channels/ChannelsTest.kt | 4 ---- .../common/test/channels/ConflatedBroadcastChannelTest.kt | 4 ---- .../common/test/channels/ConflatedChannelTest.kt | 4 ---- kotlinx-coroutines-core/common/test/channels/ConsumeTest.kt | 4 ---- .../common/test/channels/ProduceConsumeTest.kt | 4 ---- kotlinx-coroutines-core/common/test/channels/ProduceTest.kt | 4 ---- .../common/test/channels/RendezvousChannelTest.kt | 4 ---- .../common/test/channels/SendReceiveStressTest.kt | 4 ---- .../common/test/channels/TestBroadcastChannelKind.kt | 4 ---- .../common/test/channels/TestChannelKind.kt | 4 ---- .../common/test/channels/UnlimitedChannelTest.kt | 4 ---- kotlinx-coroutines-core/common/test/flow/BuildersTest.kt | 4 ---- .../common/test/flow/FlowInvariantsTest.kt | 4 ---- kotlinx-coroutines-core/common/test/flow/IdFlowTest.kt | 4 ---- .../common/test/flow/NamedDispatchers.kt | 4 ---- kotlinx-coroutines-core/common/test/flow/SafeFlowTest.kt | 4 ---- kotlinx-coroutines-core/common/test/flow/VirtualTime.kt | 4 ---- .../common/test/flow/channels/ChannelBuildersFlowTest.kt | 4 ---- .../common/test/flow/channels/ChannelFlowTest.kt | 4 ---- .../common/test/flow/channels/FlowCallbackTest.kt | 4 ---- .../common/test/flow/internal/FlowScopeTest.kt | 4 ---- .../common/test/flow/operators/BufferConflationTest.kt | 4 ---- .../common/test/flow/operators/BufferTest.kt | 4 ---- .../common/test/flow/operators/CancellableTest.kt | 4 ---- .../common/test/flow/operators/CatchTest.kt | 4 ---- .../common/test/flow/operators/CombineParametersTestBase.kt | 4 ---- .../common/test/flow/operators/CombineTest.kt | 3 --- .../common/test/flow/operators/ConflateTest.kt | 4 ---- .../common/test/flow/operators/DebounceTest.kt | 4 ---- .../common/test/flow/operators/DistinctUntilChangedTest.kt | 4 ---- .../common/test/flow/operators/DropTest.kt | 4 ---- .../common/test/flow/operators/DropWhileTest.kt | 4 ---- .../common/test/flow/operators/FilterTest.kt | 4 ---- .../common/test/flow/operators/FilterTrivialTest.kt | 3 --- .../common/test/flow/operators/FlatMapBaseTest.kt | 4 ---- .../common/test/flow/operators/FlatMapConcatTest.kt | 4 ---- .../common/test/flow/operators/FlatMapLatestTest.kt | 4 ---- .../common/test/flow/operators/FlatMapMergeBaseTest.kt | 5 ----- .../common/test/flow/operators/FlatMapMergeFastPathTest.kt | 4 ---- .../common/test/flow/operators/FlatMapMergeTest.kt | 4 ---- .../common/test/flow/operators/FlattenConcatTest.kt | 4 ---- .../common/test/flow/operators/FlattenMergeTest.kt | 4 ---- .../test/flow/operators/FlowContextOptimizationsTest.kt | 4 ---- .../common/test/flow/operators/FlowOnTest.kt | 4 ---- .../common/test/flow/operators/IndexedTest.kt | 4 ---- .../common/test/flow/operators/LintTest.kt | 4 ---- .../common/test/flow/operators/MapNotNullTest.kt | 4 ---- .../common/test/flow/operators/MapTest.kt | 4 ---- .../common/test/flow/operators/MergeTest.kt | 4 ---- .../common/test/flow/operators/OnCompletionTest.kt | 4 ---- .../common/test/flow/operators/OnEachTest.kt | 4 ---- .../common/test/flow/operators/OnEmptyTest.kt | 4 ---- .../common/test/flow/operators/OnStartTest.kt | 4 ---- .../common/test/flow/operators/RetryTest.kt | 4 ---- .../common/test/flow/operators/SampleTest.kt | 4 ---- .../common/test/flow/operators/ScanTest.kt | 4 ---- .../common/test/flow/operators/TakeTest.kt | 4 ---- .../common/test/flow/operators/TakeWhileTest.kt | 4 ---- .../common/test/flow/operators/TimeoutTest.kt | 4 ---- .../common/test/flow/operators/TransformLatestTest.kt | 4 ---- .../common/test/flow/operators/TransformTest.kt | 4 ---- .../common/test/flow/operators/TransformWhileTest.kt | 4 ---- .../common/test/flow/operators/ZipTest.kt | 4 ---- .../common/test/flow/sharing/ShareInBufferTest.kt | 4 ---- .../common/test/flow/sharing/ShareInConflationTest.kt | 4 ---- .../common/test/flow/sharing/ShareInFusionTest.kt | 4 ---- .../common/test/flow/sharing/ShareInTest.kt | 4 ---- .../common/test/flow/sharing/SharedFlowScenarioTest.kt | 4 ---- .../common/test/flow/sharing/SharedFlowTest.kt | 4 ---- .../common/test/flow/sharing/SharingStartedTest.kt | 4 ---- .../test/flow/sharing/SharingStartedWhileSubscribedTest.kt | 4 ---- .../common/test/flow/sharing/StateFlowTest.kt | 4 ---- .../common/test/flow/sharing/StateInTest.kt | 4 ---- .../common/test/flow/terminal/CollectLatestTest.kt | 4 ---- .../common/test/flow/terminal/CountTest.kt | 4 ---- .../common/test/flow/terminal/FirstTest.kt | 4 ---- .../common/test/flow/terminal/FoldTest.kt | 4 ---- .../common/test/flow/terminal/LastTest.kt | 4 ---- .../common/test/flow/terminal/LaunchFlow.kt | 4 ---- .../common/test/flow/terminal/LaunchInTest.kt | 4 ---- .../common/test/flow/terminal/ReduceTest.kt | 4 ---- .../common/test/flow/terminal/SingleTest.kt | 4 ---- .../common/test/flow/terminal/ToCollectionTest.kt | 4 ---- .../common/test/selects/SelectBiasTest.kt | 4 ---- .../common/test/selects/SelectBufferedChannelTest.kt | 4 ---- .../common/test/selects/SelectDeferredTest.kt | 4 ---- .../common/test/selects/SelectJobTest.kt | 4 ---- .../common/test/selects/SelectLoopTest.kt | 4 ---- .../common/test/selects/SelectMutexTest.kt | 4 ---- .../common/test/selects/SelectOldTest.kt | 4 ---- .../common/test/selects/SelectRendezvousChannelTest.kt | 3 --- .../common/test/selects/SelectTimeoutDurationTest.kt | 4 ---- .../common/test/selects/SelectTimeoutTest.kt | 4 ---- .../common/test/selects/SelectUnlimitedChannelTest.kt | 4 ---- kotlinx-coroutines-core/common/test/sync/MutexTest.kt | 4 ---- .../concurrent/src/Builders.concurrent.kt | 4 ---- kotlinx-coroutines-core/concurrent/src/CompletionHandler.kt | 4 ---- kotlinx-coroutines-core/concurrent/src/Dispatchers.kt | 4 ---- .../concurrent/src/MultithreadedDispatchers.common.kt | 4 ---- .../concurrent/src/internal/LockFreeLinkedList.kt | 3 --- .../concurrent/src/internal/OnDemandAllocatingPool.kt | 4 ---- .../concurrent/test/AbstractDispatcherConcurrencyTest.kt | 3 --- .../concurrent/test/AtomicCancellationTest.kt | 4 ---- .../concurrent/test/CommonThreadLocalTest.kt | 4 ---- .../concurrent/test/ConcurrentExceptionsStressTest.kt | 4 ---- .../concurrent/test/ConcurrentTestUtilities.common.kt | 4 ---- .../concurrent/test/DefaultDispatchersConcurrencyTest.kt | 3 --- .../concurrent/test/JobStructuredJoinStressTest.kt | 4 ---- .../concurrent/test/LimitedParallelismConcurrentTest.kt | 4 ---- .../concurrent/test/MultithreadedDispatcherStressTest.kt | 4 ---- kotlinx-coroutines-core/concurrent/test/RunBlockingTest.kt | 3 --- .../test/channels/BroadcastChannelSubStressTest.kt | 4 ---- .../channels/ChannelCancelUndeliveredElementStressTest.kt | 4 ---- .../channels/ConflatedBroadcastChannelNotifyStressTest.kt | 4 ---- .../concurrent/test/channels/TrySendBlockingTest.kt | 4 ---- .../concurrent/test/flow/CombineStressTest.kt | 4 ---- .../concurrent/test/flow/FlowCancellationTest.kt | 4 ---- .../concurrent/test/flow/StateFlowCommonStressTest.kt | 4 ---- .../concurrent/test/flow/StateFlowUpdateCommonTest.kt | 4 ---- .../concurrent/test/selects/SelectChannelStressTest.kt | 4 ---- .../concurrent/test/selects/SelectMutexStressTest.kt | 4 ---- .../concurrent/test/sync/MutexStressTest.kt | 4 ---- .../concurrent/test/sync/SemaphoreStressTest.kt | 4 ---- kotlinx-coroutines-core/jdk8/src/future/Future.kt | 4 ---- kotlinx-coroutines-core/jdk8/src/stream/Stream.kt | 4 ---- kotlinx-coroutines-core/jdk8/src/time/Time.kt | 3 --- kotlinx-coroutines-core/js/src/CompletionHandler.kt | 4 ---- kotlinx-coroutines-core/js/src/CoroutineContext.kt | 4 ---- kotlinx-coroutines-core/js/src/Debug.kt | 4 ---- kotlinx-coroutines-core/js/src/JSDispatcher.kt | 4 ---- kotlinx-coroutines-core/js/src/Promise.kt | 4 ---- kotlinx-coroutines-core/js/src/Window.kt | 4 ---- kotlinx-coroutines-core/js/src/internal/CopyOnWriteList.kt | 4 ---- .../js/src/internal/CoroutineExceptionHandlerImpl.kt | 4 ---- kotlinx-coroutines-core/js/test/PromiseTest.kt | 4 ---- kotlinx-coroutines-core/js/test/TestBase.kt | 4 ---- .../jsAndWasmShared/src/CloseableCoroutineDispatcher.kt | 4 ---- kotlinx-coroutines-core/jsAndWasmShared/src/Dispatchers.kt | 4 ---- kotlinx-coroutines-core/jsAndWasmShared/src/EventLoop.kt | 4 ---- kotlinx-coroutines-core/jsAndWasmShared/src/Exceptions.kt | 4 ---- kotlinx-coroutines-core/jsAndWasmShared/src/Runnable.kt | 4 ---- .../jsAndWasmShared/src/SchedulerTask.kt | 4 ---- .../jsAndWasmShared/src/flow/internal/FlowExceptions.kt | 4 ---- .../jsAndWasmShared/src/flow/internal/SafeCollector.kt | 4 ---- .../jsAndWasmShared/src/internal/Concurrent.kt | 4 ---- .../src/internal/CoroutineExceptionHandlerImpl.kt | 4 ---- .../jsAndWasmShared/src/internal/JSDispatcher.kt | 4 ---- .../jsAndWasmShared/src/internal/LinkedList.kt | 4 ---- .../jsAndWasmShared/src/internal/LocalAtomics.kt | 4 ---- .../jsAndWasmShared/src/internal/ProbesSupport.kt | 4 ---- .../jsAndWasmShared/src/internal/StackTraceRecovery.kt | 4 ---- .../jsAndWasmShared/src/internal/Synchronized.kt | 4 ---- .../jsAndWasmShared/src/internal/SystemProps.kt | 4 ---- .../jsAndWasmShared/src/internal/ThreadContext.kt | 4 ---- .../jsAndWasmShared/src/internal/ThreadLocal.kt | 4 ---- .../jsAndWasmShared/test/ImmediateDispatcherTest.kt | 4 ---- .../jsAndWasmShared/test/MessageQueueTest.kt | 4 ---- .../jsAndWasmShared/test/SetTimeoutDispatcherTest.kt | 4 ---- .../jsAndWasmShared/test/internal/LinkedListTest.kt | 4 ---- kotlinx-coroutines-core/jvm/src/AbstractTimeSource.kt | 4 ---- kotlinx-coroutines-core/jvm/src/Builders.kt | 4 ---- kotlinx-coroutines-core/jvm/src/CoroutineContext.kt | 4 ---- kotlinx-coroutines-core/jvm/src/Debug.kt | 4 ---- kotlinx-coroutines-core/jvm/src/DebugStrings.kt | 4 ---- kotlinx-coroutines-core/jvm/src/DefaultExecutor.kt | 4 ---- kotlinx-coroutines-core/jvm/src/Dispatchers.kt | 4 ---- kotlinx-coroutines-core/jvm/src/EventLoop.kt | 4 ---- kotlinx-coroutines-core/jvm/src/Exceptions.kt | 4 ---- kotlinx-coroutines-core/jvm/src/Executors.kt | 4 ---- kotlinx-coroutines-core/jvm/src/Future.kt | 4 ---- kotlinx-coroutines-core/jvm/src/Interruptible.kt | 4 ---- kotlinx-coroutines-core/jvm/src/Runnable.kt | 4 ---- kotlinx-coroutines-core/jvm/src/SchedulerTask.kt | 4 ---- kotlinx-coroutines-core/jvm/src/ThreadContextElement.kt | 4 ---- kotlinx-coroutines-core/jvm/src/ThreadPoolDispatcher.kt | 4 ---- kotlinx-coroutines-core/jvm/src/channels/Actor.kt | 4 ---- kotlinx-coroutines-core/jvm/src/channels/TickerChannels.kt | 4 ---- kotlinx-coroutines-core/jvm/src/debug/AgentPremain.kt | 4 ---- kotlinx-coroutines-core/jvm/src/debug/CoroutineDebugging.kt | 4 ---- .../jvm/src/debug/internal/AgentInstallationType.kt | 4 ---- .../jvm/src/debug/internal/ConcurrentWeakMap.kt | 4 ---- .../jvm/src/debug/internal/DebugCoroutineInfo.kt | 4 ---- .../jvm/src/debug/internal/DebugCoroutineInfoImpl.kt | 4 ---- .../jvm/src/debug/internal/DebugProbes.kt | 4 ---- .../jvm/src/debug/internal/DebugProbesImpl.kt | 4 ---- .../jvm/src/debug/internal/DebuggerInfo.kt | 4 ---- .../jvm/src/debug/internal/StackTraceFrame.kt | 4 ---- .../jvm/src/flow/internal/FlowExceptions.kt | 4 ---- .../jvm/src/flow/internal/SafeCollector.kt | 4 ---- kotlinx-coroutines-core/jvm/src/internal/Concurrent.kt | 4 ---- .../jvm/src/internal/CoroutineExceptionHandlerImpl.kt | 4 ---- .../jvm/src/internal/ExceptionsConstructor.kt | 4 ---- .../jvm/src/internal/FastServiceLoader.kt | 4 ---- .../jvm/src/internal/InternalAnnotations.kt | 4 ---- kotlinx-coroutines-core/jvm/src/internal/LocalAtomics.kt | 4 ---- kotlinx-coroutines-core/jvm/src/internal/MainDispatchers.kt | 4 ---- kotlinx-coroutines-core/jvm/src/internal/ProbesSupport.kt | 3 --- .../jvm/src/internal/ResizableAtomicArray.kt | 4 ---- .../jvm/src/internal/StackTraceRecovery.kt | 4 ---- kotlinx-coroutines-core/jvm/src/internal/Synchronized.kt | 4 ---- kotlinx-coroutines-core/jvm/src/internal/SystemProps.kt | 4 ---- kotlinx-coroutines-core/jvm/src/internal/ThreadContext.kt | 4 ---- kotlinx-coroutines-core/jvm/src/internal/ThreadLocal.kt | 4 ---- .../jvm/src/scheduling/CoroutineScheduler.kt | 4 ---- kotlinx-coroutines-core/jvm/src/scheduling/Deprecated.kt | 4 ---- kotlinx-coroutines-core/jvm/src/scheduling/Dispatcher.kt | 4 ---- kotlinx-coroutines-core/jvm/src/scheduling/Tasks.kt | 4 ---- kotlinx-coroutines-core/jvm/src/scheduling/WorkQueue.kt | 4 ---- kotlinx-coroutines-core/jvm/test/AbstractLincheckTest.kt | 3 --- kotlinx-coroutines-core/jvm/test/AsyncJvmTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/AwaitJvmTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/AwaitStressTest.kt | 4 ---- .../jvm/test/CancellableContinuationJvmTest.kt | 4 ---- .../test/CancellableContinuationResumeCloseStressTest.kt | 4 ---- .../jvm/test/CancelledAwaitStressTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/ConcurrentTestUtilities.kt | 4 ---- kotlinx-coroutines-core/jvm/test/CoroutinesJvmTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/DebugThreadNameTest.kt | 4 ---- .../jvm/test/DefaultExecutorStressTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/DelayJvmTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/DispatcherKeyTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/DispatchersToStringTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/EventLoopsTest.kt | 4 ---- .../jvm/test/ExecutorAsCoroutineDispatcherDelayTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/ExecutorRule.kt | 4 ---- kotlinx-coroutines-core/jvm/test/ExecutorsTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/FailFastOnStartTest.kt | 4 ---- .../jvm/test/FailingCoroutinesMachineryTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/FieldWalker.kt | 4 ---- kotlinx-coroutines-core/jvm/test/IODispatcherTest.kt | 4 ---- .../test/IntellijIdeaDebuggerEvaluatorCompatibilityTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/JobActivationStressTest.kt | 4 ---- .../jvm/test/JobCancellationExceptionSerializerTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/JobChildStressTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/JobDisposeStressTest.kt | 4 ---- .../jvm/test/JobHandlersUpgradeStressTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/JobStressTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/JoinStressTest.kt | 4 ---- .../jvm/test/LimitedParallelismStressTest.kt | 4 ---- .../jvm/test/LimitedParallelismUnhandledExceptionTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/MemoryFootprintTest.kt | 4 ---- .../jvm/test/MutexCancellationStressTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/NoParamAssertionsTest.kt | 3 --- kotlinx-coroutines-core/jvm/test/RejectedExecutionTest.kt | 4 ---- .../ReusableCancellableContinuationInvariantStressTest.kt | 4 ---- .../test/ReusableCancellableContinuationLeakStressTest.kt | 4 ---- .../jvm/test/ReusableCancellableContinuationTest.kt | 4 ---- .../jvm/test/ReusableContinuationStressTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/RunBlockingJvmTest.kt | 3 --- .../jvm/test/RunInterruptibleStressTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/RunInterruptibleTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/TestBase.kt | 4 ---- kotlinx-coroutines-core/jvm/test/TestBaseTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/TestSecurityManager.kt | 4 ---- .../jvm/test/ThreadContextElementRestoreTest.kt | 4 ---- .../jvm/test/ThreadContextElementTest.kt | 4 ---- .../jvm/test/ThreadContextMutableCopiesTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/ThreadContextOrderTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/ThreadLocalStressTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/ThreadLocalTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/Threads.kt | 4 ---- .../jvm/test/UnconfinedConcurrentStressTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/VirtualTimeSource.kt | 4 ---- kotlinx-coroutines-core/jvm/test/WithDefaultContextTest.kt | 4 ---- .../jvm/test/WithTimeoutChildDipspatchStressTest.kt | 4 ---- .../jvm/test/WithTimeoutOrNullJvmTest.kt | 4 ---- .../jvm/test/WithTimeoutOrNullThreadDispatchTest.kt | 4 ---- .../jvm/test/WithTimeoutThreadDispatchTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/channels/ActorLazyTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/channels/ActorTest.kt | 4 ---- .../test/channels/BroadcastChannelMultiReceiveStressTest.kt | 4 ---- .../jvm/test/channels/BufferedChannelStressTest.kt | 4 ---- .../jvm/test/channels/ChannelMemoryLeakStressTest.kt | 4 ---- .../jvm/test/channels/ChannelSelectStressTest.kt | 4 ---- .../jvm/test/channels/ChannelSendReceiveStressTest.kt | 4 ---- .../ChannelUndeliveredElementSelectOldStressTest.kt | 4 ---- .../test/channels/ChannelUndeliveredElementStressTest.kt | 4 ---- .../jvm/test/channels/ConflatedChannelCloseStressTest.kt | 4 ---- .../jvm/test/channels/DoubleChannelCloseStressTest.kt | 4 ---- .../jvm/test/channels/InvokeOnCloseStressTest.kt | 4 ---- .../jvm/test/channels/ProduceConsumeJvmTest.kt | 4 ---- .../jvm/test/channels/SendReceiveJvmStressTest.kt | 4 ---- .../jvm/test/channels/SimpleSendReceiveJvmTest.kt | 4 ---- .../jvm/test/channels/TickerChannelCommonTest.kt | 4 ---- .../jvm/test/channels/TickerChannelTest.kt | 4 ---- .../jvm/test/examples/example-delay-01.kt | 4 ---- .../jvm/test/examples/example-delay-02.kt | 4 ---- .../jvm/test/examples/example-delay-03.kt | 4 ---- .../jvm/test/examples/example-delay-duration-01.kt | 4 ---- .../jvm/test/examples/example-delay-duration-02.kt | 4 ---- .../jvm/test/examples/example-delay-duration-03.kt | 4 ---- .../jvm/test/examples/example-timeout-duration-01.kt | 4 ---- .../jvm/test/examples/test/FlowDelayTest.kt | 4 ---- .../jvm/test/exceptions/CoroutineExceptionHandlerJvmTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/exceptions/Exceptions.kt | 4 ---- .../jvm/test/exceptions/FlowSuppressionTest.kt | 4 ---- .../jvm/test/exceptions/JobBasicCancellationTest.kt | 4 ---- .../jvm/test/exceptions/JobExceptionHandlingTest.kt | 4 ---- .../jvm/test/exceptions/JobExceptionsStressTest.kt | 4 ---- .../jvm/test/exceptions/JobNestedExceptionsTest.kt | 4 ---- .../jvm/test/exceptions/ProduceExceptionsTest.kt | 4 ---- .../jvm/test/exceptions/StackTraceRecoveryChannelsTest.kt | 4 ---- .../exceptions/StackTraceRecoveryCustomExceptionsTest.kt | 4 ---- .../jvm/test/exceptions/StackTraceRecoveryNestedTest.kt | 4 ---- .../jvm/test/exceptions/StackTraceRecoveryResumeModeTest.kt | 4 ---- .../jvm/test/exceptions/StackTraceRecoverySelectTest.kt | 4 ---- .../jvm/test/exceptions/StackTraceRecoveryTest.kt | 4 ---- .../test/exceptions/StackTraceRecoveryWithTimeoutTest.kt | 4 ---- .../jvm/test/exceptions/SuppressionTests.kt | 4 ---- .../test/exceptions/WithContextCancellationStressTest.kt | 4 ---- .../jvm/test/exceptions/WithContextExceptionHandlingTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/flow/CallbackFlowTest.kt | 4 ---- .../jvm/test/flow/ExceptionTransparencyTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/flow/FirstJvmTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/flow/FlatMapStressTest.kt | 4 ---- .../jvm/test/flow/OnCompletionInterceptedReleaseTest.kt | 4 ---- .../jvm/test/flow/SafeCollectorMemoryLeakTest.kt | 4 ---- .../jvm/test/flow/SharedFlowStressTest.kt | 4 ---- .../jvm/test/flow/SharingReferenceTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/flow/SharingStressTest.kt | 4 ---- .../jvm/test/flow/StateFlowCancellabilityTest.kt | 4 ---- .../jvm/test/flow/StateFlowStressTest.kt | 4 ---- .../jvm/test/flow/StateFlowUpdateStressTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-basic-01.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-basic-02.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-basic-03.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-basic-04.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-basic-05.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-basic-06.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-cancel-01.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-cancel-02.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-cancel-03.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-cancel-04.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-cancel-05.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-cancel-06.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-cancel-07.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-cancel-08.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-cancel-09.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-cancel-10.kt | 4 ---- .../jvm/test/guide/example-channel-01.kt | 4 ---- .../jvm/test/guide/example-channel-02.kt | 4 ---- .../jvm/test/guide/example-channel-03.kt | 4 ---- .../jvm/test/guide/example-channel-04.kt | 4 ---- .../jvm/test/guide/example-channel-05.kt | 4 ---- .../jvm/test/guide/example-channel-06.kt | 4 ---- .../jvm/test/guide/example-channel-07.kt | 4 ---- .../jvm/test/guide/example-channel-08.kt | 4 ---- .../jvm/test/guide/example-channel-09.kt | 4 ---- .../jvm/test/guide/example-channel-10.kt | 4 ---- .../jvm/test/guide/example-compose-01.kt | 4 ---- .../jvm/test/guide/example-compose-02.kt | 4 ---- .../jvm/test/guide/example-compose-03.kt | 4 ---- .../jvm/test/guide/example-compose-04.kt | 4 ---- .../jvm/test/guide/example-compose-05.kt | 4 ---- .../jvm/test/guide/example-compose-06.kt | 4 ---- .../jvm/test/guide/example-context-01.kt | 4 ---- .../jvm/test/guide/example-context-02.kt | 4 ---- .../jvm/test/guide/example-context-03.kt | 4 ---- .../jvm/test/guide/example-context-04.kt | 4 ---- .../jvm/test/guide/example-context-05.kt | 4 ---- .../jvm/test/guide/example-context-06.kt | 4 ---- .../jvm/test/guide/example-context-07.kt | 4 ---- .../jvm/test/guide/example-context-08.kt | 4 ---- .../jvm/test/guide/example-context-09.kt | 4 ---- .../jvm/test/guide/example-context-10.kt | 4 ---- .../jvm/test/guide/example-context-11.kt | 4 ---- .../jvm/test/guide/example-exceptions-01.kt | 4 ---- .../jvm/test/guide/example-exceptions-02.kt | 4 ---- .../jvm/test/guide/example-exceptions-03.kt | 4 ---- .../jvm/test/guide/example-exceptions-04.kt | 4 ---- .../jvm/test/guide/example-exceptions-05.kt | 4 ---- .../jvm/test/guide/example-exceptions-06.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-01.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-02.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-03.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-04.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-05.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-06.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-07.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-08.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-09.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-10.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-11.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-12.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-13.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-14.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-15.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-16.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-17.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-18.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-19.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-20.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-21.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-22.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-23.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-24.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-25.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-26.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-27.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-28.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-29.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-30.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-31.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-32.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-33.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-34.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-35.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-36.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-37.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-38.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-flow-39.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-select-01.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-select-02.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-select-03.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-select-04.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-select-05.kt | 4 ---- .../jvm/test/guide/example-supervision-01.kt | 4 ---- .../jvm/test/guide/example-supervision-02.kt | 4 ---- .../jvm/test/guide/example-supervision-03.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-sync-01.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-sync-02.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-sync-03.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-sync-04.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-sync-05.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-sync-06.kt | 4 ---- kotlinx-coroutines-core/jvm/test/guide/example-sync-07.kt | 4 ---- .../jvm/test/guide/test/BasicsGuideTest.kt | 4 ---- .../jvm/test/guide/test/CancellationGuideTest.kt | 4 ---- .../jvm/test/guide/test/ChannelsGuideTest.kt | 4 ---- .../jvm/test/guide/test/ComposingGuideTest.kt | 4 ---- .../jvm/test/guide/test/DispatcherGuideTest.kt | 4 ---- .../jvm/test/guide/test/ExceptionsGuideTest.kt | 4 ---- .../jvm/test/guide/test/FlowGuideTest.kt | 4 ---- .../jvm/test/guide/test/SelectGuideTest.kt | 4 ---- .../jvm/test/guide/test/SharedStateGuideTest.kt | 4 ---- .../test/internal/ConcurrentWeakMapCollectionStressTest.kt | 4 ---- .../test/internal/ConcurrentWeakMapOperationStressTest.kt | 4 ---- .../jvm/test/internal/ConcurrentWeakMapTest.kt | 4 ---- .../jvm/test/internal/LockFreeLinkedListLongStressTest.kt | 4 ---- .../jvm/test/internal/LockFreeTaskQueueStressTest.kt | 4 ---- .../jvm/test/internal/LockFreeTaskQueueTest.kt | 4 ---- .../jvm/test/internal/OnDemandAllocatingPoolLincheckTest.kt | 4 ---- .../jvm/test/internal/ThreadSafeHeapStressTest.kt | 4 ---- .../jvm/test/internal/ThreadSafeHeapTest.kt | 4 ---- .../jvm/test/jdk8/future/AsFutureTest.kt | 4 ---- .../FutureAsDeferredUnhandledCompletionExceptionTest.kt | 4 ---- .../jvm/test/jdk8/future/FutureExceptionsTest.kt | 4 ---- kotlinx-coroutines-core/jvm/test/jdk8/future/FutureTest.kt | 4 ---- .../jvm/test/jdk8/stream/ConsumeAsFlowTest.kt | 4 ---- .../jvm/test/jdk8/time/DurationOverflowTest.kt | 4 ---- .../jvm/test/jdk8/time/FlowDebounceTest.kt | 4 ---- .../jvm/test/jdk8/time/FlowSampleTest.kt | 4 ---- .../jvm/test/jdk8/time/WithTimeoutTest.kt | 4 ---- .../jvm/test/knit/ClosedAfterGuideTestExecutor.kt | 4 ---- kotlinx-coroutines-core/jvm/test/knit/TestUtil.kt | 4 ---- .../jvm/test/lincheck/ChannelsLincheckTest.kt | 3 --- .../jvm/test/lincheck/LockFreeTaskQueueLincheckTest.kt | 3 --- .../jvm/test/lincheck/MutexLincheckTest.kt | 3 --- .../jvm/test/lincheck/ResizableAtomicArrayLincheckTest.kt | 4 ---- .../jvm/test/lincheck/SemaphoreLincheckTest.kt | 3 --- .../BlockingCoroutineDispatcherLivenessStressTest.kt | 4 ---- .../BlockingCoroutineDispatcherMixedStealingStressTest.kt | 4 ---- .../BlockingCoroutineDispatcherTerminationStressTest.kt | 4 ---- .../jvm/test/scheduling/BlockingCoroutineDispatcherTest.kt | 4 ---- .../BlockingCoroutineDispatcherThreadLimitStressTest.kt | 4 ---- .../BlockingCoroutineDispatcherWorkSignallingStressTest.kt | 4 ---- .../jvm/test/scheduling/CoroutineDispatcherTest.kt | 4 ---- .../test/scheduling/CoroutineSchedulerCloseStressTest.kt | 4 ---- .../scheduling/CoroutineSchedulerInternalApiStressTest.kt | 4 ---- .../test/scheduling/CoroutineSchedulerLivenessStressTest.kt | 4 ---- .../scheduling/CoroutineSchedulerOversubscriptionTest.kt | 4 ---- .../jvm/test/scheduling/CoroutineSchedulerStressTest.kt | 4 ---- .../jvm/test/scheduling/CoroutineSchedulerTest.kt | 4 ---- .../jvm/test/scheduling/DefaultDispatchersTest.kt | 4 ---- .../scheduling/LimitingCoroutineDispatcherStressTest.kt | 4 ---- .../jvm/test/scheduling/LimitingDispatcherTest.kt | 4 ---- .../jvm/test/scheduling/SchedulerTestBase.kt | 4 ---- .../jvm/test/scheduling/SharingWorkerClassTest.kt | 4 ---- .../jvm/test/scheduling/TestTimeSource.kt | 4 ---- .../jvm/test/scheduling/WorkQueueStressTest.kt | 4 ---- .../jvm/test/scheduling/WorkQueueTest.kt | 4 ---- .../jvm/test/selects/SelectDeadlockStressTest.kt | 4 ---- .../jvm/test/selects/SelectMemoryLeakStressTest.kt | 4 ---- .../jvm/test/selects/SelectPhilosophersStressTest.kt | 4 ---- .../kotlin/kotlinx/coroutines/BenchmarkUtils.kt | 4 ---- .../kotlin/kotlinx/coroutines/SemaphoreBenchmark.kt | 4 ---- .../coroutines/channels/ChannelProducerConsumerBenchmark.kt | 4 ---- .../kotlin/kotlinx/coroutines/channels/SelectBenchmark.kt | 4 ---- .../kotlin/kotlinx/coroutines/channels/SimpleChannel.kt | 4 ---- .../kotlinx/coroutines/channels/SimpleChannelBenchmark.kt | 4 ---- .../kotlin/kotlinx/coroutines/flow/TakeWhileBenchmark.kt | 4 ---- kotlinx-coroutines-core/knit.properties | 4 ---- kotlinx-coroutines-core/native/src/Builders.kt | 4 ---- .../native/src/CloseableCoroutineDispatcher.kt | 4 ---- kotlinx-coroutines-core/native/src/CoroutineContext.kt | 4 ---- kotlinx-coroutines-core/native/src/Debug.kt | 4 ---- kotlinx-coroutines-core/native/src/Dispatchers.kt | 4 ---- kotlinx-coroutines-core/native/src/EventLoop.kt | 4 ---- kotlinx-coroutines-core/native/src/Exceptions.kt | 4 ---- .../native/src/MultithreadedDispatchers.kt | 4 ---- kotlinx-coroutines-core/native/src/Runnable.kt | 4 ---- kotlinx-coroutines-core/native/src/SchedulerTask.kt | 4 ---- .../native/src/flow/internal/FlowExceptions.kt | 4 ---- .../native/src/flow/internal/SafeCollector.kt | 4 ---- kotlinx-coroutines-core/native/src/internal/Concurrent.kt | 4 ---- .../native/src/internal/CopyOnWriteList.kt | 4 ---- .../native/src/internal/CoroutineExceptionHandlerImpl.kt | 4 ---- kotlinx-coroutines-core/native/src/internal/LocalAtomics.kt | 4 ---- .../native/src/internal/ProbesSupport.kt | 4 ---- .../native/src/internal/StackTraceRecovery.kt | 4 ---- kotlinx-coroutines-core/native/src/internal/Synchronized.kt | 4 ---- kotlinx-coroutines-core/native/src/internal/SystemProps.kt | 4 ---- .../native/src/internal/ThreadContext.kt | 4 ---- kotlinx-coroutines-core/native/src/internal/ThreadLocal.kt | 4 ---- .../native/test/ConcurrentTestUtilities.kt | 4 ---- kotlinx-coroutines-core/native/test/DelayExceptionTest.kt | 4 ---- .../native/test/MultithreadedDispatchersTest.kt | 4 ---- kotlinx-coroutines-core/native/test/TestBase.kt | 4 ---- kotlinx-coroutines-core/native/test/WorkerTest.kt | 4 ---- kotlinx-coroutines-core/nativeDarwin/src/Dispatchers.kt | 4 ---- kotlinx-coroutines-core/nativeDarwin/test/Launcher.kt | 4 ---- .../nativeDarwin/test/MainDispatcherTest.kt | 4 ---- kotlinx-coroutines-core/nativeOther/src/Dispatchers.kt | 4 ---- kotlinx-coroutines-core/nativeOther/test/Launcher.kt | 4 ---- kotlinx-coroutines-core/wasmJs/src/CompletionHandler.kt | 4 ---- kotlinx-coroutines-core/wasmJs/src/CoroutineContext.kt | 4 ---- kotlinx-coroutines-core/wasmJs/src/Debug.kt | 4 ---- kotlinx-coroutines-core/wasmJs/src/JSDispatcher.kt | 4 ---- kotlinx-coroutines-core/wasmJs/src/Promise.kt | 4 ---- .../wasmJs/src/internal/CopyOnWriteList.kt | 4 ---- .../wasmJs/src/internal/CoroutineExceptionHandlerImpl.kt | 4 ---- kotlinx-coroutines-core/wasmJs/test/PromiseTest.kt | 4 ---- kotlinx-coroutines-core/wasmJs/test/TestBase.kt | 4 ---- kotlinx-coroutines-debug/build.gradle.kts | 4 ---- kotlinx-coroutines-debug/src/CoroutineInfo.kt | 3 --- .../src/CoroutinesBlockHoundIntegration.kt | 4 ---- kotlinx-coroutines-debug/src/DebugProbes.kt | 4 ---- kotlinx-coroutines-debug/src/internal/Attach.kt | 3 --- kotlinx-coroutines-debug/src/internal/NoOpProbes.kt | 4 ---- kotlinx-coroutines-debug/src/junit/CoroutinesTimeoutImpl.kt | 4 ---- .../src/junit/junit4/CoroutinesTimeout.kt | 4 ---- .../src/junit/junit4/CoroutinesTimeoutStatement.kt | 4 ---- .../src/junit/junit5/CoroutinesTimeout.kt | 4 ---- .../src/junit/junit5/CoroutinesTimeoutExtension.kt | 4 ---- kotlinx-coroutines-debug/test/CoroutinesDumpTest.kt | 4 ---- kotlinx-coroutines-debug/test/DebugLeaksTest.kt | 4 ---- kotlinx-coroutines-debug/test/DebugProbesTest.kt | 3 --- kotlinx-coroutines-debug/test/DebugTestBase.kt | 3 --- .../test/DumpCoroutineInfoAsJsonAndReferencesTest.kt | 3 --- .../test/DumpWithoutCreationStackTraceTest.kt | 3 --- .../test/EnhanceStackTraceWithTreadDumpAsJsonTest.kt | 3 --- kotlinx-coroutines-debug/test/LazyCoroutineTest.kt | 3 --- kotlinx-coroutines-debug/test/RecoveryExample.kt | 3 --- .../test/RunningThreadStackMergeTest.kt | 3 --- kotlinx-coroutines-debug/test/SanitizedProbesTest.kt | 4 ---- kotlinx-coroutines-debug/test/ScopedBuildersTest.kt | 4 ---- kotlinx-coroutines-debug/test/StacktraceUtils.kt | 4 ---- kotlinx-coroutines-debug/test/StandardBuildersDebugTest.kt | 3 --- kotlinx-coroutines-debug/test/StartModeProbesTest.kt | 4 ---- kotlinx-coroutines-debug/test/TestRuleExample.kt | 4 ---- kotlinx-coroutines-debug/test/ToStringTest.kt | 4 ---- .../test/WithContextUndispatchedTest.kt | 3 --- .../test/junit4/CoroutinesTimeoutDisabledTracesTest.kt | 4 ---- .../test/junit4/CoroutinesTimeoutEagerTest.kt | 4 ---- .../test/junit4/CoroutinesTimeoutTest.kt | 4 ---- .../test/junit4/TestFailureValidation.kt | 4 ---- .../test/junit5/CoroutinesTimeoutExtensionTest.kt | 4 ---- .../test/junit5/CoroutinesTimeoutInheritanceTest.kt | 4 ---- .../test/junit5/CoroutinesTimeoutMethodTest.kt | 4 ---- .../test/junit5/CoroutinesTimeoutNestedTest.kt | 4 ---- .../test/junit5/CoroutinesTimeoutSimpleTest.kt | 4 ---- .../test/junit5/CoroutinesTimeoutTest.kt | 4 ---- .../test/junit5/RegisterExtensionExample.kt | 4 ---- kotlinx-coroutines-test/build.gradle.kts | 4 ---- kotlinx-coroutines-test/common/src/TestBuilders.kt | 3 --- .../common/src/TestCoroutineDispatchers.kt | 4 ---- .../common/src/TestCoroutineScheduler.kt | 4 ---- kotlinx-coroutines-test/common/src/TestDispatcher.kt | 4 ---- kotlinx-coroutines-test/common/src/TestDispatchers.kt | 3 --- kotlinx-coroutines-test/common/src/TestScope.kt | 4 ---- .../common/src/internal/ExceptionCollector.kt | 4 ---- .../common/src/internal/ReportingSupervisorJob.kt | 4 ---- .../common/src/internal/TestMainDispatcher.kt | 4 ---- kotlinx-coroutines-test/common/test/Helpers.kt | 4 ---- kotlinx-coroutines-test/common/test/RunTestTest.kt | 4 ---- .../common/test/StandardTestDispatcherTest.kt | 4 ---- .../common/test/TestCoroutineSchedulerTest.kt | 4 ---- kotlinx-coroutines-test/common/test/TestDispatchersTest.kt | 3 --- kotlinx-coroutines-test/common/test/TestScopeTest.kt | 4 ---- .../common/test/UnconfinedTestDispatcherTest.kt | 4 ---- kotlinx-coroutines-test/js/src/TestBuilders.kt | 4 ---- .../js/src/internal/TestMainDispatcher.kt | 4 ---- kotlinx-coroutines-test/js/test/Helpers.kt | 4 ---- kotlinx-coroutines-test/js/test/PromiseTest.kt | 3 --- kotlinx-coroutines-test/jvm/src/TestBuildersJvm.kt | 3 --- .../jvm/src/internal/TestMainDispatcherJvm.kt | 4 ---- .../jvm/src/migration/DelayController.kt | 3 --- .../jvm/src/migration/TestBuildersDeprecated.kt | 3 --- .../jvm/src/migration/TestCoroutineDispatcher.kt | 4 ---- .../jvm/src/migration/TestCoroutineExceptionHandler.kt | 4 ---- .../jvm/src/migration/TestCoroutineScope.kt | 3 --- kotlinx-coroutines-test/jvm/test/DumpOnTimeoutTest.kt | 4 ---- kotlinx-coroutines-test/jvm/test/HelpersJvm.kt | 3 --- kotlinx-coroutines-test/jvm/test/MemoryLeakTest.kt | 3 --- kotlinx-coroutines-test/jvm/test/MultithreadingTest.kt | 4 ---- kotlinx-coroutines-test/jvm/test/RunTestStressTest.kt | 3 --- kotlinx-coroutines-test/jvm/test/UncaughtExceptionsTest.kt | 3 --- .../jvm/test/migration/RunBlockingTestOnTestScopeTest.kt | 4 ---- .../jvm/test/migration/RunTestLegacyScopeTest.kt | 4 ---- .../jvm/test/migration/TestBuildersTest.kt | 4 ---- .../jvm/test/migration/TestCoroutineDispatcherOrderTest.kt | 4 ---- .../jvm/test/migration/TestCoroutineDispatcherTest.kt | 4 ---- .../jvm/test/migration/TestCoroutineExceptionHandlerTest.kt | 4 ---- .../jvm/test/migration/TestCoroutineScopeTest.kt | 3 --- .../jvm/test/migration/TestRunBlockingOrderTest.kt | 4 ---- .../jvm/test/migration/TestRunBlockingTest.kt | 4 ---- kotlinx-coroutines-test/native/src/TestBuilders.kt | 4 ---- .../native/src/internal/TestMainDispatcher.kt | 4 ---- kotlinx-coroutines-test/native/test/Helpers.kt | 3 --- kotlinx-coroutines-test/wasmJs/src/TestBuilders.kt | 4 ---- .../wasmJs/src/internal/TestMainDispatcher.kt | 4 ---- kotlinx-coroutines-test/wasmJs/test/Helpers.kt | 4 ---- kotlinx-coroutines-test/wasmJs/test/PromiseTest.kt | 3 --- license/NOTICE.txt | 2 +- reactive/knit.properties | 4 ---- reactive/knit.test.include | 4 ---- reactive/kotlinx-coroutines-jdk9/build.gradle.kts | 4 ---- reactive/kotlinx-coroutines-jdk9/src/Await.kt | 4 ---- reactive/kotlinx-coroutines-jdk9/src/Publish.kt | 4 ---- reactive/kotlinx-coroutines-jdk9/src/ReactiveFlow.kt | 4 ---- reactive/kotlinx-coroutines-jdk9/test/AwaitTest.kt | 4 ---- .../kotlinx-coroutines-jdk9/test/FlowAsPublisherTest.kt | 4 ---- reactive/kotlinx-coroutines-jdk9/test/IntegrationTest.kt | 4 ---- reactive/kotlinx-coroutines-jdk9/test/PublishTest.kt | 4 ---- .../kotlinx-coroutines-jdk9/test/PublisherAsFlowTest.kt | 4 ---- .../test/PublisherBackpressureTest.kt | 4 ---- .../kotlinx-coroutines-jdk9/test/PublisherCollectTest.kt | 4 ---- .../test/PublisherCompletionStressTest.kt | 4 ---- reactive/kotlinx-coroutines-jdk9/test/PublisherMultiTest.kt | 4 ---- reactive/kotlinx-coroutines-reactive/build.gradle.kts | 4 ---- reactive/kotlinx-coroutines-reactive/src/Await.kt | 4 ---- reactive/kotlinx-coroutines-reactive/src/Channel.kt | 4 ---- reactive/kotlinx-coroutines-reactive/src/ContextInjector.kt | 4 ---- reactive/kotlinx-coroutines-reactive/src/Convert.kt | 4 ---- reactive/kotlinx-coroutines-reactive/src/Migration.kt | 4 ---- reactive/kotlinx-coroutines-reactive/src/Publish.kt | 3 --- reactive/kotlinx-coroutines-reactive/src/ReactiveFlow.kt | 4 ---- .../test/AwaitCancellationStressTest.kt | 4 ---- reactive/kotlinx-coroutines-reactive/test/AwaitTest.kt | 4 ---- .../test/CancelledParentAttachTest.kt | 4 ---- .../kotlinx-coroutines-reactive/test/FlowAsPublisherTest.kt | 4 ---- .../kotlinx-coroutines-reactive/test/IntegrationTest.kt | 4 ---- .../kotlinx-coroutines-reactive/test/IterableFlowTckTest.kt | 4 ---- reactive/kotlinx-coroutines-reactive/test/PublishTest.kt | 4 ---- .../kotlinx-coroutines-reactive/test/PublisherAsFlowTest.kt | 4 ---- .../test/PublisherBackpressureTest.kt | 4 ---- .../test/PublisherCollectTest.kt | 4 ---- .../test/PublisherCompletionStressTest.kt | 4 ---- .../kotlinx-coroutines-reactive/test/PublisherMultiTest.kt | 4 ---- .../test/PublisherRequestStressTest.kt | 4 ---- .../test/PublisherSubscriptionSelectTest.kt | 4 ---- .../test/RangePublisherBufferedTest.kt | 4 ---- .../kotlinx-coroutines-reactive/test/RangePublisherTest.kt | 4 ---- .../test/ReactiveStreamTckTest.kt | 4 ---- .../test/UnboundedIntegerIncrementPublisherTest.kt | 4 ---- reactive/kotlinx-coroutines-reactor/build.gradle.kts | 4 ---- reactive/kotlinx-coroutines-reactor/src/Convert.kt | 4 ---- reactive/kotlinx-coroutines-reactor/src/Flux.kt | 4 ---- reactive/kotlinx-coroutines-reactor/src/Migration.kt | 4 ---- reactive/kotlinx-coroutines-reactor/src/Mono.kt | 4 ---- reactive/kotlinx-coroutines-reactor/src/ReactorContext.kt | 4 ---- .../src/ReactorContextInjector.kt | 4 ---- reactive/kotlinx-coroutines-reactor/src/ReactorFlow.kt | 4 ---- reactive/kotlinx-coroutines-reactor/src/Scheduler.kt | 4 ---- .../kotlinx-coroutines-reactor/test/BackpressureTest.kt | 4 ---- reactive/kotlinx-coroutines-reactor/test/Check.kt | 4 ---- reactive/kotlinx-coroutines-reactor/test/ConvertTest.kt | 4 ---- .../test/FluxCompletionStressTest.kt | 4 ---- reactive/kotlinx-coroutines-reactor/test/FluxContextTest.kt | 4 ---- reactive/kotlinx-coroutines-reactor/test/FluxMultiTest.kt | 4 ---- reactive/kotlinx-coroutines-reactor/test/FluxSingleTest.kt | 4 ---- reactive/kotlinx-coroutines-reactor/test/FluxTest.kt | 4 ---- .../kotlinx-coroutines-reactor/test/MonoAwaitStressTest.kt | 4 ---- reactive/kotlinx-coroutines-reactor/test/MonoTest.kt | 4 ---- reactive/kotlinx-coroutines-reactor/test/SchedulerTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/build.gradle | 3 --- reactive/kotlinx-coroutines-rx2/src/RxAwait.kt | 4 ---- reactive/kotlinx-coroutines-rx2/src/RxCancellable.kt | 4 ---- reactive/kotlinx-coroutines-rx2/src/RxChannel.kt | 4 ---- reactive/kotlinx-coroutines-rx2/src/RxCompletable.kt | 4 ---- reactive/kotlinx-coroutines-rx2/src/RxConvert.kt | 4 ---- reactive/kotlinx-coroutines-rx2/src/RxFlowable.kt | 4 ---- reactive/kotlinx-coroutines-rx2/src/RxMaybe.kt | 4 ---- reactive/kotlinx-coroutines-rx2/src/RxObservable.kt | 4 ---- reactive/kotlinx-coroutines-rx2/src/RxScheduler.kt | 4 ---- reactive/kotlinx-coroutines-rx2/src/RxSingle.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/BackpressureTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/Check.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/CompletableTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/ConvertTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/FlowAsFlowableTest.kt | 4 ---- .../kotlinx-coroutines-rx2/test/FlowAsObservableTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/FlowableContextTest.kt | 4 ---- .../test/FlowableExceptionHandlingTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/FlowableTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/IntegrationTest.kt | 4 ---- .../test/IterableFlowAsFlowableTckTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/LeakedExceptionTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/MaybeTest.kt | 4 ---- .../kotlinx-coroutines-rx2/test/ObservableAsFlowTest.kt | 4 ---- .../kotlinx-coroutines-rx2/test/ObservableCollectTest.kt | 4 ---- .../test/ObservableCompletionStressTest.kt | 4 ---- .../test/ObservableExceptionHandlingTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/ObservableMultiTest.kt | 4 ---- .../kotlinx-coroutines-rx2/test/ObservableSingleTest.kt | 4 ---- .../test/ObservableSourceAsFlowStressTest.kt | 4 ---- .../test/ObservableSubscriptionSelectTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/ObservableTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/SchedulerStressTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/SchedulerTest.kt | 4 ---- reactive/kotlinx-coroutines-rx2/test/SingleTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/build.gradle | 3 --- reactive/kotlinx-coroutines-rx3/src/RxAwait.kt | 4 ---- reactive/kotlinx-coroutines-rx3/src/RxCancellable.kt | 4 ---- reactive/kotlinx-coroutines-rx3/src/RxChannel.kt | 4 ---- reactive/kotlinx-coroutines-rx3/src/RxCompletable.kt | 4 ---- reactive/kotlinx-coroutines-rx3/src/RxConvert.kt | 4 ---- reactive/kotlinx-coroutines-rx3/src/RxFlowable.kt | 4 ---- reactive/kotlinx-coroutines-rx3/src/RxMaybe.kt | 4 ---- reactive/kotlinx-coroutines-rx3/src/RxObservable.kt | 4 ---- reactive/kotlinx-coroutines-rx3/src/RxScheduler.kt | 4 ---- reactive/kotlinx-coroutines-rx3/src/RxSingle.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/BackpressureTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/Check.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/CompletableTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/ConvertTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/FlowAsFlowableTest.kt | 4 ---- .../kotlinx-coroutines-rx3/test/FlowAsObservableTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/FlowableContextTest.kt | 4 ---- .../test/FlowableExceptionHandlingTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/FlowableTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/IntegrationTest.kt | 4 ---- .../test/IterableFlowAsFlowableTckTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/LeakedExceptionTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/MaybeTest.kt | 4 ---- .../kotlinx-coroutines-rx3/test/ObservableAsFlowTest.kt | 4 ---- .../kotlinx-coroutines-rx3/test/ObservableCollectTest.kt | 4 ---- .../test/ObservableCompletionStressTest.kt | 4 ---- .../test/ObservableExceptionHandlingTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/ObservableMultiTest.kt | 4 ---- .../kotlinx-coroutines-rx3/test/ObservableSingleTest.kt | 4 ---- .../test/ObservableSourceAsFlowStressTest.kt | 4 ---- .../test/ObservableSubscriptionSelectTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/ObservableTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/SchedulerStressTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/SchedulerTest.kt | 4 ---- reactive/kotlinx-coroutines-rx3/test/SingleTest.kt | 4 ---- settings.gradle | 4 ---- ui/knit.code.include | 4 ---- ui/knit.properties | 4 ---- .../android-unit-tests/build.gradle.kts | 4 ---- .../android-unit-tests/src/EmptyCoroutineScopeImpl.kt | 4 ---- .../test/ordered/tests/CustomizedRobolectricTest.kt | 4 ---- .../test/ordered/tests/FirstMockedMainTest.kt | 4 ---- .../test/ordered/tests/FirstRobolectricTest.kt | 4 ---- .../android-unit-tests/test/ordered/tests/MockedMainTest.kt | 4 ---- .../test/ordered/tests/RobolectricTest.kt | 3 --- .../android-unit-tests/test/ordered/tests/TestComponent.kt | 4 ---- ui/kotlinx-coroutines-android/build.gradle.kts | 4 ---- .../src/AndroidExceptionPreHandler.kt | 4 ---- ui/kotlinx-coroutines-android/src/HandlerDispatcher.kt | 4 ---- .../test/AndroidExceptionPreHandlerTest.kt | 4 ---- ui/kotlinx-coroutines-android/test/DisabledHandlerTest.kt | 4 ---- .../test/HandlerDispatcherAsyncTest.kt | 4 ---- ui/kotlinx-coroutines-android/test/HandlerDispatcherTest.kt | 4 ---- .../test/R8ServiceLoaderOptimizationTest.kt | 4 ---- ui/kotlinx-coroutines-javafx/build.gradle.kts | 4 ---- ui/kotlinx-coroutines-javafx/src/JavaFxConvert.kt | 4 ---- ui/kotlinx-coroutines-javafx/src/JavaFxDispatcher.kt | 4 ---- ui/kotlinx-coroutines-javafx/test/JavaFxDispatcherTest.kt | 4 ---- ui/kotlinx-coroutines-javafx/test/examples/FxExampleApp.kt | 4 ---- .../test/guide/example-ui-actor-01.kt | 4 ---- .../test/guide/example-ui-actor-02.kt | 4 ---- .../test/guide/example-ui-actor-03.kt | 4 ---- .../test/guide/example-ui-advanced-01.kt | 4 ---- .../test/guide/example-ui-advanced-02.kt | 4 ---- .../test/guide/example-ui-basic-01.kt | 4 ---- .../test/guide/example-ui-basic-02.kt | 4 ---- .../test/guide/example-ui-basic-03.kt | 4 ---- .../test/guide/example-ui-blocking-01.kt | 4 ---- .../test/guide/example-ui-blocking-02.kt | 4 ---- .../test/guide/example-ui-blocking-03.kt | 4 ---- ui/kotlinx-coroutines-swing/build.gradle.kts | 4 ---- ui/kotlinx-coroutines-swing/src/SwingDispatcher.kt | 4 ---- ui/kotlinx-coroutines-swing/test/SwingTest.kt | 4 ---- .../test/examples/SwingExampleApp.kt | 4 ---- 1054 files changed, 2 insertions(+), 4137 deletions(-) delete mode 100644 .idea/copyright/kotlinx_coroutines.xml diff --git a/.idea/copyright/kotlinx_coroutines.xml b/.idea/copyright/kotlinx_coroutines.xml deleted file mode 100644 index f175624311..0000000000 --- a/.idea/copyright/kotlinx_coroutines.xml +++ /dev/null @@ -1,6 +0,0 @@ - - - - \ No newline at end of file diff --git a/LICENSE.txt b/LICENSE.txt index 9c308d958b..9477ff6795 100644 --- a/LICENSE.txt +++ b/LICENSE.txt @@ -187,7 +187,7 @@ same "printed page" as the copyright notice for easier identification within third-party archives. - Copyright 2000-2020 JetBrains s.r.o. and Kotlin Programming Language contributors. + Copyright 2016-2024 JetBrains s.r.o. and Kotlin Programming Language contributors. Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with the License. diff --git a/benchmarks/build.gradle.kts b/benchmarks/build.gradle.kts index 5b99f27eae..7006c915d9 100644 --- a/benchmarks/build.gradle.kts +++ b/benchmarks/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("UnstableApiUsage") import org.jetbrains.kotlin.gradle.tasks.* diff --git a/benchmarks/src/jmh/java/benchmarks/flow/scrabble/RxJava2PlaysScrabble.java b/benchmarks/src/jmh/java/benchmarks/flow/scrabble/RxJava2PlaysScrabble.java index 6d9169d3d6..c5530f525b 100644 --- a/benchmarks/src/jmh/java/benchmarks/flow/scrabble/RxJava2PlaysScrabble.java +++ b/benchmarks/src/jmh/java/benchmarks/flow/scrabble/RxJava2PlaysScrabble.java @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow.scrabble; import benchmarks.flow.scrabble.IterableSpliterator; diff --git a/benchmarks/src/jmh/java/benchmarks/flow/scrabble/RxJava2PlaysScrabbleOpt.java b/benchmarks/src/jmh/java/benchmarks/flow/scrabble/RxJava2PlaysScrabbleOpt.java index 2d900cad87..bf40759b59 100644 --- a/benchmarks/src/jmh/java/benchmarks/flow/scrabble/RxJava2PlaysScrabbleOpt.java +++ b/benchmarks/src/jmh/java/benchmarks/flow/scrabble/RxJava2PlaysScrabbleOpt.java @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow.scrabble; import java.util.*; diff --git a/benchmarks/src/jmh/java/benchmarks/flow/scrabble/optimizations/FlowableCharSequence.java b/benchmarks/src/jmh/java/benchmarks/flow/scrabble/optimizations/FlowableCharSequence.java index 0acf98d0d2..63f347f409 100644 --- a/benchmarks/src/jmh/java/benchmarks/flow/scrabble/optimizations/FlowableCharSequence.java +++ b/benchmarks/src/jmh/java/benchmarks/flow/scrabble/optimizations/FlowableCharSequence.java @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow.scrabble.optimizations; import io.reactivex.Flowable; diff --git a/benchmarks/src/jmh/java/benchmarks/flow/scrabble/optimizations/FlowableSplit.java b/benchmarks/src/jmh/java/benchmarks/flow/scrabble/optimizations/FlowableSplit.java index 1c78f5eca0..020285cb32 100644 --- a/benchmarks/src/jmh/java/benchmarks/flow/scrabble/optimizations/FlowableSplit.java +++ b/benchmarks/src/jmh/java/benchmarks/flow/scrabble/optimizations/FlowableSplit.java @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow.scrabble.optimizations; import io.reactivex.Flowable; diff --git a/benchmarks/src/jmh/java/benchmarks/flow/scrabble/optimizations/StringFlowable.java b/benchmarks/src/jmh/java/benchmarks/flow/scrabble/optimizations/StringFlowable.java index f51112b45f..ee40a5a331 100644 --- a/benchmarks/src/jmh/java/benchmarks/flow/scrabble/optimizations/StringFlowable.java +++ b/benchmarks/src/jmh/java/benchmarks/flow/scrabble/optimizations/StringFlowable.java @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow.scrabble.optimizations; import io.reactivex.Flowable; diff --git a/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkBenchmark.kt index f706d3aa03..51061cce72 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkDepthBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkDepthBenchmark.kt index d3f6be6770..18a140f31b 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkDepthBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkDepthBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkNoAllocationsBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkNoAllocationsBenchmark.kt index dcba8383ad..8dec5f2a19 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkNoAllocationsBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/ChannelSinkNoAllocationsBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/ParametrizedDispatcherBase.kt b/benchmarks/src/jmh/kotlin/benchmarks/ParametrizedDispatcherBase.kt index ce64c6a49b..da80958516 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/ParametrizedDispatcherBase.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/ParametrizedDispatcherBase.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks import benchmarks.akka.CORES_COUNT diff --git a/benchmarks/src/jmh/kotlin/benchmarks/SequentialSemaphoreBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/SequentialSemaphoreBenchmark.kt index 6926db783a..ed1a4ed89a 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/SequentialSemaphoreBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/SequentialSemaphoreBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/akka/PingPongAkkaBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/akka/PingPongAkkaBenchmark.kt index df94075258..30e590b0a6 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/akka/PingPongAkkaBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/akka/PingPongAkkaBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.akka import akka.actor.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/akka/StatefulActorAkkaBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/akka/StatefulActorAkkaBenchmark.kt index fef641ae7b..d7be75a56c 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/akka/StatefulActorAkkaBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/akka/StatefulActorAkkaBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.akka import akka.actor.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/debug/DebugSequenceOverheadBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/debug/DebugSequenceOverheadBenchmark.kt index 16e93e1f1b..ec37840514 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/debug/DebugSequenceOverheadBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/debug/DebugSequenceOverheadBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.debug import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/CombineFlowsBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/CombineFlowsBenchmark.kt index be371548fe..207b2453ab 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/CombineFlowsBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/CombineFlowsBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/CombineTwoFlowsBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/CombineTwoFlowsBenchmark.kt index bc8d8687a4..dd385353fc 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/CombineTwoFlowsBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/CombineTwoFlowsBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/FlatMapMergeBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/FlatMapMergeBenchmark.kt index 32d35475db..772e1bb11a 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/FlatMapMergeBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/FlatMapMergeBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/FlowFlattenMergeBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/FlowFlattenMergeBenchmark.kt index 09d841eb75..f89ed9d1fd 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/FlowFlattenMergeBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/FlowFlattenMergeBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow import benchmarks.common.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/NumbersBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/NumbersBenchmark.kt index 636b334dbf..697b876cac 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/NumbersBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/NumbersBenchmark.kt @@ -1,8 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - - package benchmarks.flow import benchmarks.flow.scrabble.flow diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/SafeFlowBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/SafeFlowBenchmark.kt index d957bdbe0e..f1b0fafb01 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/SafeFlowBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/SafeFlowBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/TakeBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/TakeBenchmark.kt index a0a2decced..b22e5a231a 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/TakeBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/TakeBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/FlowPlaysScrabbleBase.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/FlowPlaysScrabbleBase.kt index b8e1f4509a..fc2923d9b9 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/FlowPlaysScrabbleBase.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/FlowPlaysScrabbleBase.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow.scrabble import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/FlowPlaysScrabbleOpt.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/FlowPlaysScrabbleOpt.kt index cd27cca0ed..16190f89ca 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/FlowPlaysScrabbleOpt.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/FlowPlaysScrabbleOpt.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow.scrabble import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/IterableSpliterator.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/IterableSpliterator.kt index e78d7bd080..cce343cd6f 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/IterableSpliterator.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/IterableSpliterator.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow.scrabble import java.util.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/ReactorPlaysScrabble.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/ReactorPlaysScrabble.kt index 1db4dae09e..3ab22da8c2 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/ReactorPlaysScrabble.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/ReactorPlaysScrabble.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow.scrabble import reactor.core.publisher.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/SaneFlowPlaysScrabble.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/SaneFlowPlaysScrabble.kt index 533bc5e6db..596a2ad39d 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/SaneFlowPlaysScrabble.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/SaneFlowPlaysScrabble.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow.scrabble import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/SequencePlaysScrabble.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/SequencePlaysScrabble.kt index acfb3f3c6d..eca01dfa4a 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/SequencePlaysScrabble.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/SequencePlaysScrabble.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow.scrabble import kotlinx.coroutines.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/ShakespearePlaysScrabble.kt b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/ShakespearePlaysScrabble.kt index 10433fcb45..a2e5d2c178 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/ShakespearePlaysScrabble.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/flow/scrabble/ShakespearePlaysScrabble.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.flow.scrabble import org.openjdk.jmh.annotations.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/DispatchersContextSwitchBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/DispatchersContextSwitchBenchmark.kt index 1fe709266d..fba05101e1 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/DispatchersContextSwitchBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/DispatchersContextSwitchBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.scheduler import benchmarks.akka.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/ForkJoinBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/ForkJoinBenchmark.kt index 20bdfa349a..5572858c06 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/ForkJoinBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/ForkJoinBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.scheduler import benchmarks.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/LaunchBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/LaunchBenchmark.kt index d64fdd2f7d..18c58cdab9 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/LaunchBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/LaunchBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.scheduler import benchmarks.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/StatefulAwaitsBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/StatefulAwaitsBenchmark.kt index c5b34eda90..14bc44b9a6 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/StatefulAwaitsBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/StatefulAwaitsBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.scheduler import benchmarks.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/ConcurrentStatefulActorBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/ConcurrentStatefulActorBenchmark.kt index 1ffb5207f0..76a674fa33 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/ConcurrentStatefulActorBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/ConcurrentStatefulActorBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.scheduler.actors import benchmarks.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/CycledActorsBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/CycledActorsBenchmark.kt index cd212cc17b..653b769b54 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/CycledActorsBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/CycledActorsBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.scheduler.actors import benchmarks.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/PingPongActorBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/PingPongActorBenchmark.kt index d696c64ffc..9c524e845a 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/PingPongActorBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/PingPongActorBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.scheduler.actors import benchmarks.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/PingPongWithBlockingContext.kt b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/PingPongWithBlockingContext.kt index d874f3bbe1..9bebea71dc 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/PingPongWithBlockingContext.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/PingPongWithBlockingContext.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.scheduler.actors import benchmarks.akka.* diff --git a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/StatefulActorBenchmark.kt b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/StatefulActorBenchmark.kt index eebcec0152..0b03dba57a 100644 --- a/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/StatefulActorBenchmark.kt +++ b/benchmarks/src/jmh/kotlin/benchmarks/scheduler/actors/StatefulActorBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.scheduler.actors import benchmarks.* diff --git a/benchmarks/src/main/kotlin/benchmarks/common/BenchmarkUtils.kt b/benchmarks/src/main/kotlin/benchmarks/common/BenchmarkUtils.kt index 858ecfad67..21c92c1511 100644 --- a/benchmarks/src/main/kotlin/benchmarks/common/BenchmarkUtils.kt +++ b/benchmarks/src/main/kotlin/benchmarks/common/BenchmarkUtils.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package benchmarks.common import java.util.concurrent.* diff --git a/build.gradle b/build.gradle index 16a88c764b..1053473644 100644 --- a/build.gradle +++ b/build.gradle @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.jetbrains.kotlin.config.KotlinCompilerVersion import org.jetbrains.kotlin.gradle.plugin.KotlinPlatformType import org.jetbrains.kotlin.konan.target.HostManager diff --git a/buildSrc/build.gradle.kts b/buildSrc/build.gradle.kts index 33ce6714e4..9ff7026d7e 100644 --- a/buildSrc/build.gradle.kts +++ b/buildSrc/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import java.util.* plugins { diff --git a/buildSrc/settings.gradle.kts b/buildSrc/settings.gradle.kts index c2e859f65d..2ad2ddbea6 100644 --- a/buildSrc/settings.gradle.kts +++ b/buildSrc/settings.gradle.kts @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ pluginManagement { val build_snapshot_train: String? by settings repositories { diff --git a/buildSrc/src/main/kotlin/CacheRedirector.kt b/buildSrc/src/main/kotlin/CacheRedirector.kt index 6f207dd40c..f97c199423 100644 --- a/buildSrc/src/main/kotlin/CacheRedirector.kt +++ b/buildSrc/src/main/kotlin/CacheRedirector.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.gradle.api.* import org.gradle.api.artifacts.dsl.* import org.gradle.api.artifacts.repositories.* diff --git a/buildSrc/src/main/kotlin/CommunityProjectsBuild.kt b/buildSrc/src/main/kotlin/CommunityProjectsBuild.kt index e8d9d242b7..8cb07de197 100644 --- a/buildSrc/src/main/kotlin/CommunityProjectsBuild.kt +++ b/buildSrc/src/main/kotlin/CommunityProjectsBuild.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:JvmName("CommunityProjectsBuild") import org.gradle.api.* diff --git a/buildSrc/src/main/kotlin/Dokka.kt b/buildSrc/src/main/kotlin/Dokka.kt index 6d233e8387..900375258f 100644 --- a/buildSrc/src/main/kotlin/Dokka.kt +++ b/buildSrc/src/main/kotlin/Dokka.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.gradle.api.* import org.gradle.kotlin.dsl.* import org.jetbrains.dokka.gradle.* diff --git a/buildSrc/src/main/kotlin/Idea.kt b/buildSrc/src/main/kotlin/Idea.kt index 28b4aa555e..615b8aad74 100644 --- a/buildSrc/src/main/kotlin/Idea.kt +++ b/buildSrc/src/main/kotlin/Idea.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - object Idea { @JvmStatic // for Gradle val active: Boolean diff --git a/buildSrc/src/main/kotlin/Java9Modularity.kt b/buildSrc/src/main/kotlin/Java9Modularity.kt index f3e9a6618f..17cf1fa674 100644 --- a/buildSrc/src/main/kotlin/Java9Modularity.kt +++ b/buildSrc/src/main/kotlin/Java9Modularity.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.gradle.api.* import org.gradle.api.attributes.* import org.gradle.api.file.* diff --git a/buildSrc/src/main/kotlin/OptInPreset.kt b/buildSrc/src/main/kotlin/OptInPreset.kt index fdcdb8ecf8..cb111a87a8 100644 --- a/buildSrc/src/main/kotlin/OptInPreset.kt +++ b/buildSrc/src/main/kotlin/OptInPreset.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:JvmName("OptInPreset") val optInAnnotations = listOf( diff --git a/buildSrc/src/main/kotlin/Platform.kt b/buildSrc/src/main/kotlin/Platform.kt index f22c161b6e..b667a138a8 100644 --- a/buildSrc/src/main/kotlin/Platform.kt +++ b/buildSrc/src/main/kotlin/Platform.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.gradle.api.Project // Use from Groovy for now diff --git a/buildSrc/src/main/kotlin/Projects.kt b/buildSrc/src/main/kotlin/Projects.kt index 495e41183f..011851ff49 100644 --- a/buildSrc/src/main/kotlin/Projects.kt +++ b/buildSrc/src/main/kotlin/Projects.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:JvmName("Projects") import org.gradle.api.* diff --git a/buildSrc/src/main/kotlin/Publishing.kt b/buildSrc/src/main/kotlin/Publishing.kt index d6dc598cdd..2e5028a828 100644 --- a/buildSrc/src/main/kotlin/Publishing.kt +++ b/buildSrc/src/main/kotlin/Publishing.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("UnstableApiUsage") import groovy.util.Node diff --git a/buildSrc/src/main/kotlin/SourceSets.kt b/buildSrc/src/main/kotlin/SourceSets.kt index b354784739..6fae1aac76 100644 --- a/buildSrc/src/main/kotlin/SourceSets.kt +++ b/buildSrc/src/main/kotlin/SourceSets.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ import org.jetbrains.kotlin.gradle.plugin.* fun KotlinSourceSet.configureDirectoryPaths() { diff --git a/buildSrc/src/main/kotlin/UnpackAar.kt b/buildSrc/src/main/kotlin/UnpackAar.kt index afe2627a3d..88948ac8a8 100644 --- a/buildSrc/src/main/kotlin/UnpackAar.kt +++ b/buildSrc/src/main/kotlin/UnpackAar.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.gradle.api.* import org.gradle.api.artifacts.transform.InputArtifact import org.gradle.api.artifacts.transform.TransformAction diff --git a/buildSrc/src/main/kotlin/VersionFile.kt b/buildSrc/src/main/kotlin/VersionFile.kt index ef0ef0faa1..46d19840ab 100644 --- a/buildSrc/src/main/kotlin/VersionFile.kt +++ b/buildSrc/src/main/kotlin/VersionFile.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.gradle.api.* import org.gradle.api.tasks.* diff --git a/buildSrc/src/main/kotlin/animalsniffer-conventions.gradle.kts b/buildSrc/src/main/kotlin/animalsniffer-conventions.gradle.kts index 639245b6e5..74693f9dca 100644 --- a/buildSrc/src/main/kotlin/animalsniffer-conventions.gradle.kts +++ b/buildSrc/src/main/kotlin/animalsniffer-conventions.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import ru.vyarus.gradle.plugin.animalsniffer.* configure(subprojects) { diff --git a/buildSrc/src/main/kotlin/bom-conventions.gradle.kts b/buildSrc/src/main/kotlin/bom-conventions.gradle.kts index 45f30edff1..14f365c897 100644 --- a/buildSrc/src/main/kotlin/bom-conventions.gradle.kts +++ b/buildSrc/src/main/kotlin/bom-conventions.gradle.kts @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ import org.gradle.kotlin.dsl.* import org.jetbrains.kotlin.gradle.dsl.* diff --git a/buildSrc/src/main/kotlin/configure-compilation-conventions.gradle.kts b/buildSrc/src/main/kotlin/configure-compilation-conventions.gradle.kts index 9b6699ba21..2cffaa000f 100644 --- a/buildSrc/src/main/kotlin/configure-compilation-conventions.gradle.kts +++ b/buildSrc/src/main/kotlin/configure-compilation-conventions.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.jetbrains.kotlin.gradle.dsl.* import org.jetbrains.kotlin.gradle.dsl.KotlinCompile import org.jetbrains.kotlin.gradle.tasks.* diff --git a/buildSrc/src/main/kotlin/dokka-conventions.gradle.kts b/buildSrc/src/main/kotlin/dokka-conventions.gradle.kts index 435e097bcc..966aa98e04 100644 --- a/buildSrc/src/main/kotlin/dokka-conventions.gradle.kts +++ b/buildSrc/src/main/kotlin/dokka-conventions.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.jetbrains.dokka.gradle.* import java.net.* diff --git a/buildSrc/src/main/kotlin/java-modularity-conventions.gradle.kts b/buildSrc/src/main/kotlin/java-modularity-conventions.gradle.kts index a5f72aa800..e8df676ea6 100644 --- a/buildSrc/src/main/kotlin/java-modularity-conventions.gradle.kts +++ b/buildSrc/src/main/kotlin/java-modularity-conventions.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // Currently the compilation of the module-info fails for // kotlinx-coroutines-play-services because it depends on Android JAR's // which do not have an explicit module-info descriptor. diff --git a/buildSrc/src/main/kotlin/knit-conventions.gradle.kts b/buildSrc/src/main/kotlin/knit-conventions.gradle.kts index e342dfaaeb..e606a514da 100644 --- a/buildSrc/src/main/kotlin/knit-conventions.gradle.kts +++ b/buildSrc/src/main/kotlin/knit-conventions.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - plugins { id("kotlinx-knit") } diff --git a/buildSrc/src/main/kotlin/kotlin-jvm-conventions.gradle.kts b/buildSrc/src/main/kotlin/kotlin-jvm-conventions.gradle.kts index aa7eb71ecd..34c45d13f3 100644 --- a/buildSrc/src/main/kotlin/kotlin-jvm-conventions.gradle.kts +++ b/buildSrc/src/main/kotlin/kotlin-jvm-conventions.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // Platform-specific configuration to compile JVM modules import org.gradle.api.* diff --git a/buildSrc/src/main/kotlin/kotlin-multiplatform-conventions.gradle.kts b/buildSrc/src/main/kotlin/kotlin-multiplatform-conventions.gradle.kts index 01308d7418..e222303cf9 100644 --- a/buildSrc/src/main/kotlin/kotlin-multiplatform-conventions.gradle.kts +++ b/buildSrc/src/main/kotlin/kotlin-multiplatform-conventions.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.gradle.api.* import org.gradle.api.tasks.testing.logging.* import org.jetbrains.kotlin.gradle.dsl.* diff --git a/buildSrc/src/main/kotlin/kover-conventions.gradle.kts b/buildSrc/src/main/kotlin/kover-conventions.gradle.kts index 5ad0359635..477d60fbb2 100644 --- a/buildSrc/src/main/kotlin/kover-conventions.gradle.kts +++ b/buildSrc/src/main/kotlin/kover-conventions.gradle.kts @@ -1,8 +1,5 @@ import kotlinx.kover.gradle.plugin.dsl.* -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ plugins { id("org.jetbrains.kotlinx.kover") } diff --git a/buildSrc/src/main/kotlin/pub-conventions.gradle.kts b/buildSrc/src/main/kotlin/pub-conventions.gradle.kts index 7a744b81bd..4aa99990c2 100644 --- a/buildSrc/src/main/kotlin/pub-conventions.gradle.kts +++ b/buildSrc/src/main/kotlin/pub-conventions.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.gradle.kotlin.dsl.* /* diff --git a/buildSrc/src/main/kotlin/source-set-conventions.gradle.kts b/buildSrc/src/main/kotlin/source-set-conventions.gradle.kts index 103607579a..b9b080f9ae 100644 --- a/buildSrc/src/main/kotlin/source-set-conventions.gradle.kts +++ b/buildSrc/src/main/kotlin/source-set-conventions.gradle.kts @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ import org.jetbrains.kotlin.gradle.dsl.* // Redefine source sets because we are not using 'kotlin/main/fqn' folder convention diff --git a/docs/knit.code.include b/docs/knit.code.include index 42f2b50e81..8db8d745ed 100644 --- a/docs/knit.code.include +++ b/docs/knit.code.include @@ -1,6 +1,2 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from ${file.name} by Knit tool. Do not edit. package ${knit.package}.${knit.name} \ No newline at end of file diff --git a/docs/knit.test.template b/docs/knit.test.template index 727493c662..b416374630 100644 --- a/docs/knit.test.template +++ b/docs/knit.test.template @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from ${file.name} by Knit tool. Do not edit. package ${test.package} diff --git a/docs/topics/knit.properties b/docs/topics/knit.properties index 562b4121b0..f71ccf2ae6 100644 --- a/docs/topics/knit.properties +++ b/docs/topics/knit.properties @@ -1,7 +1,3 @@ -# -# Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. -# - knit.package=kotlinx.coroutines.guide knit.dir=../../kotlinx-coroutines-core/jvm/test/guide/ diff --git a/gradle.properties b/gradle.properties index 70fdc9044d..2c6517467a 100644 --- a/gradle.properties +++ b/gradle.properties @@ -1,7 +1,3 @@ -# -# Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. -# - # Kotlin version=1.8.0-RC2-SNAPSHOT group=org.jetbrains.kotlinx diff --git a/integration-testing/build.gradle b/integration-testing/build.gradle index 1a231afbdf..64301dd9c5 100644 --- a/integration-testing/build.gradle +++ b/integration-testing/build.gradle @@ -1,8 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - - buildscript { /* diff --git a/integration-testing/smokeTest/src/commonTest/kotlin/SampleTest.kt b/integration-testing/smokeTest/src/commonTest/kotlin/SampleTest.kt index a8c6598e88..98366d87a8 100644 --- a/integration-testing/smokeTest/src/commonTest/kotlin/SampleTest.kt +++ b/integration-testing/smokeTest/src/commonTest/kotlin/SampleTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import kotlinx.coroutines.test.* import kotlin.test.* diff --git a/integration-testing/src/coreAgentTest/kotlin/CoreAgentTest.kt b/integration-testing/src/coreAgentTest/kotlin/CoreAgentTest.kt index 359338b86f..3b4dc3468f 100644 --- a/integration-testing/src/coreAgentTest/kotlin/CoreAgentTest.kt +++ b/integration-testing/src/coreAgentTest/kotlin/CoreAgentTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ import org.junit.* import kotlinx.coroutines.* import kotlinx.coroutines.debug.internal.* diff --git a/integration-testing/src/debugAgentTest/kotlin/DebugAgentTest.kt b/integration-testing/src/debugAgentTest/kotlin/DebugAgentTest.kt index 779cd5b7b8..111d4c73e1 100644 --- a/integration-testing/src/debugAgentTest/kotlin/DebugAgentTest.kt +++ b/integration-testing/src/debugAgentTest/kotlin/DebugAgentTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ import org.junit.* import kotlinx.coroutines.* import kotlinx.coroutines.debug.* diff --git a/integration-testing/src/debugAgentTest/kotlin/DebugProbes.kt b/integration-testing/src/debugAgentTest/kotlin/DebugProbes.kt index 8174156975..849d4d4e3c 100644 --- a/integration-testing/src/debugAgentTest/kotlin/DebugProbes.kt +++ b/integration-testing/src/debugAgentTest/kotlin/DebugProbes.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("INVISIBLE_MEMBER", "INVISIBLE_REFERENCE") package kotlin.coroutines.jvm.internal diff --git a/integration-testing/src/debugAgentTest/kotlin/PrecompiledDebugProbesTest.kt b/integration-testing/src/debugAgentTest/kotlin/PrecompiledDebugProbesTest.kt index ab207e092b..2a63dffb41 100644 --- a/integration-testing/src/debugAgentTest/kotlin/PrecompiledDebugProbesTest.kt +++ b/integration-testing/src/debugAgentTest/kotlin/PrecompiledDebugProbesTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ import org.junit.Test import java.io.* import kotlin.test.* diff --git a/integration-testing/src/debugDynamicAgentTest/kotlin/DynamicAttachDebugTest.kt b/integration-testing/src/debugDynamicAgentTest/kotlin/DynamicAttachDebugTest.kt index ff9cac847c..046951955e 100644 --- a/integration-testing/src/debugDynamicAgentTest/kotlin/DynamicAttachDebugTest.kt +++ b/integration-testing/src/debugDynamicAgentTest/kotlin/DynamicAttachDebugTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ import org.junit.* import kotlinx.coroutines.* import kotlinx.coroutines.debug.* diff --git a/integration-testing/src/jvmCoreTest/kotlin/Jdk8InCoreIntegration.kt b/integration-testing/src/jvmCoreTest/kotlin/Jdk8InCoreIntegration.kt index 91eef7e24b..a733f0630e 100644 --- a/integration-testing/src/jvmCoreTest/kotlin/Jdk8InCoreIntegration.kt +++ b/integration-testing/src/jvmCoreTest/kotlin/Jdk8InCoreIntegration.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines import kotlinx.coroutines.future.* diff --git a/integration-testing/src/jvmCoreTest/kotlin/ListAllCoroutineThrowableSubclassesTest.kt b/integration-testing/src/jvmCoreTest/kotlin/ListAllCoroutineThrowableSubclassesTest.kt index 7253658e9b..5c564c8a8e 100644 --- a/integration-testing/src/jvmCoreTest/kotlin/ListAllCoroutineThrowableSubclassesTest.kt +++ b/integration-testing/src/jvmCoreTest/kotlin/ListAllCoroutineThrowableSubclassesTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import com.google.common.reflect.* diff --git a/integration-testing/src/mavenTest/kotlin/MavenPublicationAtomicfuValidator.kt b/integration-testing/src/mavenTest/kotlin/MavenPublicationAtomicfuValidator.kt index 13bac0157a..a1449c1d42 100644 --- a/integration-testing/src/mavenTest/kotlin/MavenPublicationAtomicfuValidator.kt +++ b/integration-testing/src/mavenTest/kotlin/MavenPublicationAtomicfuValidator.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.validator import org.junit.Test diff --git a/integration-testing/src/mavenTest/kotlin/MavenPublicationMetaInfValidator.kt b/integration-testing/src/mavenTest/kotlin/MavenPublicationMetaInfValidator.kt index 8ed2b823f7..6033686458 100644 --- a/integration-testing/src/mavenTest/kotlin/MavenPublicationMetaInfValidator.kt +++ b/integration-testing/src/mavenTest/kotlin/MavenPublicationMetaInfValidator.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.validator import org.junit.Test diff --git a/integration-testing/src/mavenTest/kotlin/MavenPublicationVersionValidator.kt b/integration-testing/src/mavenTest/kotlin/MavenPublicationVersionValidator.kt index 11529d2d0d..0728c41604 100644 --- a/integration-testing/src/mavenTest/kotlin/MavenPublicationVersionValidator.kt +++ b/integration-testing/src/mavenTest/kotlin/MavenPublicationVersionValidator.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.validator import org.junit.Test diff --git a/integration/kotlinx-coroutines-guava/build.gradle.kts b/integration/kotlinx-coroutines-guava/build.gradle.kts index 2a84ca937e..72f34e9ddd 100644 --- a/integration/kotlinx-coroutines-guava/build.gradle.kts +++ b/integration/kotlinx-coroutines-guava/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - val guavaVersion = "31.0.1-jre" dependencies { diff --git a/integration/kotlinx-coroutines-guava/src/ListenableFuture.kt b/integration/kotlinx-coroutines-guava/src/ListenableFuture.kt index 0820f1f101..fce7217aa8 100644 --- a/integration/kotlinx-coroutines-guava/src/ListenableFuture.kt +++ b/integration/kotlinx-coroutines-guava/src/ListenableFuture.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.guava import com.google.common.util.concurrent.* diff --git a/integration/kotlinx-coroutines-guava/test/FutureAsDeferredUnhandledCompletionExceptionTest.kt b/integration/kotlinx-coroutines-guava/test/FutureAsDeferredUnhandledCompletionExceptionTest.kt index d6469a947e..ca3ce28182 100644 --- a/integration/kotlinx-coroutines-guava/test/FutureAsDeferredUnhandledCompletionExceptionTest.kt +++ b/integration/kotlinx-coroutines-guava/test/FutureAsDeferredUnhandledCompletionExceptionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.guava import com.google.common.util.concurrent.* diff --git a/integration/kotlinx-coroutines-guava/test/ListenableFutureExceptionsTest.kt b/integration/kotlinx-coroutines-guava/test/ListenableFutureExceptionsTest.kt index 7417168b02..44b06e83d0 100644 --- a/integration/kotlinx-coroutines-guava/test/ListenableFutureExceptionsTest.kt +++ b/integration/kotlinx-coroutines-guava/test/ListenableFutureExceptionsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.guava import com.google.common.base.* diff --git a/integration/kotlinx-coroutines-guava/test/ListenableFutureTest.kt b/integration/kotlinx-coroutines-guava/test/ListenableFutureTest.kt index 511b1b0322..3feed7bbb7 100644 --- a/integration/kotlinx-coroutines-guava/test/ListenableFutureTest.kt +++ b/integration/kotlinx-coroutines-guava/test/ListenableFutureTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.guava import com.google.common.util.concurrent.* diff --git a/integration/kotlinx-coroutines-guava/test/ListenableFutureToStringTest.kt b/integration/kotlinx-coroutines-guava/test/ListenableFutureToStringTest.kt index 13ac299088..1a8afe87af 100644 --- a/integration/kotlinx-coroutines-guava/test/ListenableFutureToStringTest.kt +++ b/integration/kotlinx-coroutines-guava/test/ListenableFutureToStringTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.guava import kotlinx.coroutines.* diff --git a/integration/kotlinx-coroutines-jdk8/build.gradle.kts b/integration/kotlinx-coroutines-jdk8/build.gradle.kts index 791bd95024..e69de29bb2 100644 --- a/integration/kotlinx-coroutines-jdk8/build.gradle.kts +++ b/integration/kotlinx-coroutines-jdk8/build.gradle.kts @@ -1,4 +0,0 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - diff --git a/integration/kotlinx-coroutines-play-services/build.gradle.kts b/integration/kotlinx-coroutines-play-services/build.gradle.kts index 9f8a128703..2a03440140 100644 --- a/integration/kotlinx-coroutines-play-services/build.gradle.kts +++ b/integration/kotlinx-coroutines-play-services/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - val tasksVersion = "16.0.1" project.configureAar() diff --git a/integration/kotlinx-coroutines-play-services/src/Tasks.kt b/integration/kotlinx-coroutines-play-services/src/Tasks.kt index 0451d7beb8..8a1b7bdffd 100644 --- a/integration/kotlinx-coroutines-play-services/src/Tasks.kt +++ b/integration/kotlinx-coroutines-play-services/src/Tasks.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("RedundantVisibilityModifier") package kotlinx.coroutines.tasks diff --git a/integration/kotlinx-coroutines-play-services/test/TaskTest.kt b/integration/kotlinx-coroutines-play-services/test/TaskTest.kt index 34fbe23b55..3c6687c134 100644 --- a/integration/kotlinx-coroutines-play-services/test/TaskTest.kt +++ b/integration/kotlinx-coroutines-play-services/test/TaskTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.tasks import com.google.android.gms.tasks.* diff --git a/integration/kotlinx-coroutines-slf4j/build.gradle.kts b/integration/kotlinx-coroutines-slf4j/build.gradle.kts index 3552333311..aaf0a42360 100644 --- a/integration/kotlinx-coroutines-slf4j/build.gradle.kts +++ b/integration/kotlinx-coroutines-slf4j/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - dependencies { implementation("org.slf4j:slf4j-api:1.7.32") testImplementation("io.github.microutils:kotlin-logging:2.1.0") diff --git a/integration/kotlinx-coroutines-slf4j/src/MDCContext.kt b/integration/kotlinx-coroutines-slf4j/src/MDCContext.kt index 0fbfece600..59ded36b4c 100644 --- a/integration/kotlinx-coroutines-slf4j/src/MDCContext.kt +++ b/integration/kotlinx-coroutines-slf4j/src/MDCContext.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.slf4j import kotlinx.coroutines.* diff --git a/integration/kotlinx-coroutines-slf4j/test/MDCContextTest.kt b/integration/kotlinx-coroutines-slf4j/test/MDCContextTest.kt index 532c47e9ed..2732ec711c 100644 --- a/integration/kotlinx-coroutines-slf4j/test/MDCContextTest.kt +++ b/integration/kotlinx-coroutines-slf4j/test/MDCContextTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.slf4j import kotlinx.coroutines.* diff --git a/knit.properties b/knit.properties index 45b2216db4..486204bb1f 100644 --- a/knit.properties +++ b/knit.properties @@ -1,7 +1,3 @@ -# -# Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. -# - knit.include=docs/knit.code.include test.template=docs/knit.test.template diff --git a/kotlinx-coroutines-bom/build.gradle b/kotlinx-coroutines-bom/build.gradle index d415d8c302..ad37309126 100644 --- a/kotlinx-coroutines-bom/build.gradle +++ b/kotlinx-coroutines-bom/build.gradle @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ plugins { id 'java-platform' } diff --git a/kotlinx-coroutines-core/build.gradle b/kotlinx-coroutines-core/build.gradle index 8c153cd226..a33ca74431 100644 --- a/kotlinx-coroutines-core/build.gradle +++ b/kotlinx-coroutines-core/build.gradle @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - plugins { id 'org.jetbrains.kotlinx.benchmark' version '0.4.9' } diff --git a/kotlinx-coroutines-core/common/src/AbstractCoroutine.kt b/kotlinx-coroutines-core/common/src/AbstractCoroutine.kt index 439a9ac7a5..d7d3b40725 100644 --- a/kotlinx-coroutines-core/common/src/AbstractCoroutine.kt +++ b/kotlinx-coroutines-core/common/src/AbstractCoroutine.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("DEPRECATION_ERROR") package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/src/Annotations.kt b/kotlinx-coroutines-core/common/src/Annotations.kt index bacce39408..b35da67ca5 100644 --- a/kotlinx-coroutines-core/common/src/Annotations.kt +++ b/kotlinx-coroutines-core/common/src/Annotations.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.flow.* diff --git a/kotlinx-coroutines-core/common/src/Await.kt b/kotlinx-coroutines-core/common/src/Await.kt index c1669e2554..fd78899834 100644 --- a/kotlinx-coroutines-core/common/src/Await.kt +++ b/kotlinx-coroutines-core/common/src/Await.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/Builders.common.kt b/kotlinx-coroutines-core/common/src/Builders.common.kt index bcb2dd81d6..95c1be8a8c 100644 --- a/kotlinx-coroutines-core/common/src/Builders.common.kt +++ b/kotlinx-coroutines-core/common/src/Builders.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("BuildersKt") @file:OptIn(ExperimentalContracts::class) diff --git a/kotlinx-coroutines-core/common/src/CancellableContinuation.kt b/kotlinx-coroutines-core/common/src/CancellableContinuation.kt index e3237e570c..6270b22bbf 100644 --- a/kotlinx-coroutines-core/common/src/CancellableContinuation.kt +++ b/kotlinx-coroutines-core/common/src/CancellableContinuation.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/common/src/CancellableContinuationImpl.kt b/kotlinx-coroutines-core/common/src/CancellableContinuationImpl.kt index ed2d9f2026..b1f9dca639 100644 --- a/kotlinx-coroutines-core/common/src/CancellableContinuationImpl.kt +++ b/kotlinx-coroutines-core/common/src/CancellableContinuationImpl.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/CloseableCoroutineDispatcher.kt b/kotlinx-coroutines-core/common/src/CloseableCoroutineDispatcher.kt index 541b3082e2..1ed0eb1c4f 100644 --- a/kotlinx-coroutines-core/common/src/CloseableCoroutineDispatcher.kt +++ b/kotlinx-coroutines-core/common/src/CloseableCoroutineDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines /** diff --git a/kotlinx-coroutines-core/common/src/CompletableDeferred.kt b/kotlinx-coroutines-core/common/src/CompletableDeferred.kt index 293c516721..abb6aeae46 100644 --- a/kotlinx-coroutines-core/common/src/CompletableDeferred.kt +++ b/kotlinx-coroutines-core/common/src/CompletableDeferred.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("DEPRECATION_ERROR") package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/src/CompletableJob.kt b/kotlinx-coroutines-core/common/src/CompletableJob.kt index beafdaf2ca..f3ac8dc185 100644 --- a/kotlinx-coroutines-core/common/src/CompletableJob.kt +++ b/kotlinx-coroutines-core/common/src/CompletableJob.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines /** diff --git a/kotlinx-coroutines-core/common/src/CompletionHandler.common.kt b/kotlinx-coroutines-core/common/src/CompletionHandler.common.kt index e712ff1fc1..31e2893610 100644 --- a/kotlinx-coroutines-core/common/src/CompletionHandler.common.kt +++ b/kotlinx-coroutines-core/common/src/CompletionHandler.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/common/src/CompletionState.kt b/kotlinx-coroutines-core/common/src/CompletionState.kt index 43330af460..b9fefa5ca8 100644 --- a/kotlinx-coroutines-core/common/src/CompletionState.kt +++ b/kotlinx-coroutines-core/common/src/CompletionState.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/CoroutineContext.common.kt b/kotlinx-coroutines-core/common/src/CoroutineContext.common.kt index 5f776335bf..48e59fe3a9 100644 --- a/kotlinx-coroutines-core/common/src/CoroutineContext.common.kt +++ b/kotlinx-coroutines-core/common/src/CoroutineContext.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/CoroutineDispatcher.kt b/kotlinx-coroutines-core/common/src/CoroutineDispatcher.kt index 568353bf4a..7c334ed5bb 100644 --- a/kotlinx-coroutines-core/common/src/CoroutineDispatcher.kt +++ b/kotlinx-coroutines-core/common/src/CoroutineDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/common/src/CoroutineExceptionHandler.kt b/kotlinx-coroutines-core/common/src/CoroutineExceptionHandler.kt index 30360b28ce..b69050afec 100644 --- a/kotlinx-coroutines-core/common/src/CoroutineExceptionHandler.kt +++ b/kotlinx-coroutines-core/common/src/CoroutineExceptionHandler.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/common/src/CoroutineName.kt b/kotlinx-coroutines-core/common/src/CoroutineName.kt index dc3f1c0cea..82b45c87ba 100644 --- a/kotlinx-coroutines-core/common/src/CoroutineName.kt +++ b/kotlinx-coroutines-core/common/src/CoroutineName.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.AbstractCoroutineContextElement diff --git a/kotlinx-coroutines-core/common/src/CoroutineScope.kt b/kotlinx-coroutines-core/common/src/CoroutineScope.kt index cf4c1cfc03..e7d4446a77 100644 --- a/kotlinx-coroutines-core/common/src/CoroutineScope.kt +++ b/kotlinx-coroutines-core/common/src/CoroutineScope.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:OptIn(ExperimentalContracts::class) package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/src/CoroutineStart.kt b/kotlinx-coroutines-core/common/src/CoroutineStart.kt index 540286594e..4fa5d73c82 100644 --- a/kotlinx-coroutines-core/common/src/CoroutineStart.kt +++ b/kotlinx-coroutines-core/common/src/CoroutineStart.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines import kotlinx.coroutines.CoroutineStart.* diff --git a/kotlinx-coroutines-core/common/src/Debug.common.kt b/kotlinx-coroutines-core/common/src/Debug.common.kt index 185ad295d8..07ba28baa0 100644 --- a/kotlinx-coroutines-core/common/src/Debug.common.kt +++ b/kotlinx-coroutines-core/common/src/Debug.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines internal expect val DEBUG: Boolean diff --git a/kotlinx-coroutines-core/common/src/Deferred.kt b/kotlinx-coroutines-core/common/src/Deferred.kt index 2f106e9ed3..9445f23902 100644 --- a/kotlinx-coroutines-core/common/src/Deferred.kt +++ b/kotlinx-coroutines-core/common/src/Deferred.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.selects.* diff --git a/kotlinx-coroutines-core/common/src/Delay.kt b/kotlinx-coroutines-core/common/src/Delay.kt index 313e87314d..48f78b4ea0 100644 --- a/kotlinx-coroutines-core/common/src/Delay.kt +++ b/kotlinx-coroutines-core/common/src/Delay.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.selects.* diff --git a/kotlinx-coroutines-core/common/src/Dispatchers.common.kt b/kotlinx-coroutines-core/common/src/Dispatchers.common.kt index cf7a23a1ea..7c34ead90f 100644 --- a/kotlinx-coroutines-core/common/src/Dispatchers.common.kt +++ b/kotlinx-coroutines-core/common/src/Dispatchers.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/EventLoop.common.kt b/kotlinx-coroutines-core/common/src/EventLoop.common.kt index 53c03be91e..eefb125539 100644 --- a/kotlinx-coroutines-core/common/src/EventLoop.common.kt +++ b/kotlinx-coroutines-core/common/src/EventLoop.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/Exceptions.common.kt b/kotlinx-coroutines-core/common/src/Exceptions.common.kt index a787fbb701..e19c36f273 100644 --- a/kotlinx-coroutines-core/common/src/Exceptions.common.kt +++ b/kotlinx-coroutines-core/common/src/Exceptions.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines /** diff --git a/kotlinx-coroutines-core/common/src/Job.kt b/kotlinx-coroutines-core/common/src/Job.kt index 5f40dfc194..bac6476ed5 100644 --- a/kotlinx-coroutines-core/common/src/Job.kt +++ b/kotlinx-coroutines-core/common/src/Job.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("JobKt") @file:Suppress("DEPRECATION_ERROR", "RedundantUnitReturnType") diff --git a/kotlinx-coroutines-core/common/src/JobSupport.kt b/kotlinx-coroutines-core/common/src/JobSupport.kt index baa924cb40..f1d804304b 100644 --- a/kotlinx-coroutines-core/common/src/JobSupport.kt +++ b/kotlinx-coroutines-core/common/src/JobSupport.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("DEPRECATION_ERROR") package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/src/MainCoroutineDispatcher.kt b/kotlinx-coroutines-core/common/src/MainCoroutineDispatcher.kt index 9150bd0604..8644474879 100644 --- a/kotlinx-coroutines-core/common/src/MainCoroutineDispatcher.kt +++ b/kotlinx-coroutines-core/common/src/MainCoroutineDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/common/src/NonCancellable.kt b/kotlinx-coroutines-core/common/src/NonCancellable.kt index 9fb72dddbc..afc1f6a547 100644 --- a/kotlinx-coroutines-core/common/src/NonCancellable.kt +++ b/kotlinx-coroutines-core/common/src/NonCancellable.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("DEPRECATION_ERROR") package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/src/Runnable.common.kt b/kotlinx-coroutines-core/common/src/Runnable.common.kt index 5a7f6678a4..462ed6a7fe 100644 --- a/kotlinx-coroutines-core/common/src/Runnable.common.kt +++ b/kotlinx-coroutines-core/common/src/Runnable.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines /** diff --git a/kotlinx-coroutines-core/common/src/SchedulerTask.common.kt b/kotlinx-coroutines-core/common/src/SchedulerTask.common.kt index ae3ffcce10..3eea46c4a7 100644 --- a/kotlinx-coroutines-core/common/src/SchedulerTask.common.kt +++ b/kotlinx-coroutines-core/common/src/SchedulerTask.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines internal expect abstract class SchedulerTask internal constructor() : Runnable diff --git a/kotlinx-coroutines-core/common/src/Supervisor.kt b/kotlinx-coroutines-core/common/src/Supervisor.kt index 8411c5c65a..6773da6cc8 100644 --- a/kotlinx-coroutines-core/common/src/Supervisor.kt +++ b/kotlinx-coroutines-core/common/src/Supervisor.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:OptIn(ExperimentalContracts::class) @file:Suppress("DEPRECATION_ERROR") diff --git a/kotlinx-coroutines-core/common/src/Timeout.kt b/kotlinx-coroutines-core/common/src/Timeout.kt index 3ce74c00d0..930b39ccc0 100644 --- a/kotlinx-coroutines-core/common/src/Timeout.kt +++ b/kotlinx-coroutines-core/common/src/Timeout.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:OptIn(ExperimentalContracts::class) package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/src/Unconfined.kt b/kotlinx-coroutines-core/common/src/Unconfined.kt index 5837ae83f3..46ea4ea191 100644 --- a/kotlinx-coroutines-core/common/src/Unconfined.kt +++ b/kotlinx-coroutines-core/common/src/Unconfined.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/Waiter.kt b/kotlinx-coroutines-core/common/src/Waiter.kt index 79d3dbf564..cc037d9d21 100644 --- a/kotlinx-coroutines-core/common/src/Waiter.kt +++ b/kotlinx-coroutines-core/common/src/Waiter.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.Segment diff --git a/kotlinx-coroutines-core/common/src/Yield.kt b/kotlinx-coroutines-core/common/src/Yield.kt index db3bfa5359..c6a157f10e 100644 --- a/kotlinx-coroutines-core/common/src/Yield.kt +++ b/kotlinx-coroutines-core/common/src/Yield.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/common/src/channels/Broadcast.kt b/kotlinx-coroutines-core/common/src/channels/Broadcast.kt index 64b6a69595..bcfab771b6 100644 --- a/kotlinx-coroutines-core/common/src/channels/Broadcast.kt +++ b/kotlinx-coroutines-core/common/src/channels/Broadcast.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("DEPRECATION") package kotlinx.coroutines.channels diff --git a/kotlinx-coroutines-core/common/src/channels/BroadcastChannel.kt b/kotlinx-coroutines-core/common/src/channels/BroadcastChannel.kt index a967b673cc..059bcdcf31 100644 --- a/kotlinx-coroutines-core/common/src/channels/BroadcastChannel.kt +++ b/kotlinx-coroutines-core/common/src/channels/BroadcastChannel.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("FunctionName", "DEPRECATION") package kotlinx.coroutines.channels diff --git a/kotlinx-coroutines-core/common/src/channels/BufferOverflow.kt b/kotlinx-coroutines-core/common/src/channels/BufferOverflow.kt index 8af2c845e7..e6263838a8 100644 --- a/kotlinx-coroutines-core/common/src/channels/BufferOverflow.kt +++ b/kotlinx-coroutines-core/common/src/channels/BufferOverflow.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels /** diff --git a/kotlinx-coroutines-core/common/src/channels/Channel.kt b/kotlinx-coroutines-core/common/src/channels/Channel.kt index b14e61bbd2..c225c0835d 100644 --- a/kotlinx-coroutines-core/common/src/channels/Channel.kt +++ b/kotlinx-coroutines-core/common/src/channels/Channel.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("FunctionName") package kotlinx.coroutines.channels diff --git a/kotlinx-coroutines-core/common/src/channels/ChannelCoroutine.kt b/kotlinx-coroutines-core/common/src/channels/ChannelCoroutine.kt index 7b6bd02605..44bbf5353b 100644 --- a/kotlinx-coroutines-core/common/src/channels/ChannelCoroutine.kt +++ b/kotlinx-coroutines-core/common/src/channels/ChannelCoroutine.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/channels/Channels.common.kt b/kotlinx-coroutines-core/common/src/channels/Channels.common.kt index 35c8c266db..092b3b14f0 100644 --- a/kotlinx-coroutines-core/common/src/channels/Channels.common.kt +++ b/kotlinx-coroutines-core/common/src/channels/Channels.common.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:JvmMultifileClass @file:JvmName("ChannelsKt") @file:OptIn(ExperimentalContracts::class) diff --git a/kotlinx-coroutines-core/common/src/channels/ConflatedBufferedChannel.kt b/kotlinx-coroutines-core/common/src/channels/ConflatedBufferedChannel.kt index 699030725b..a2d3a10322 100644 --- a/kotlinx-coroutines-core/common/src/channels/ConflatedBufferedChannel.kt +++ b/kotlinx-coroutines-core/common/src/channels/ConflatedBufferedChannel.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/channels/Deprecated.kt b/kotlinx-coroutines-core/common/src/channels/Deprecated.kt index 9220a8600e..acb8daf50a 100644 --- a/kotlinx-coroutines-core/common/src/channels/Deprecated.kt +++ b/kotlinx-coroutines-core/common/src/channels/Deprecated.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:JvmMultifileClass @file:JvmName("ChannelsKt") @file:Suppress("unused") diff --git a/kotlinx-coroutines-core/common/src/channels/Produce.kt b/kotlinx-coroutines-core/common/src/channels/Produce.kt index da8f884be1..85f1df5057 100644 --- a/kotlinx-coroutines-core/common/src/channels/Produce.kt +++ b/kotlinx-coroutines-core/common/src/channels/Produce.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/flow/Builders.kt b/kotlinx-coroutines-core/common/src/flow/Builders.kt index 350cc4be76..d56666f37f 100644 --- a/kotlinx-coroutines-core/common/src/flow/Builders.kt +++ b/kotlinx-coroutines-core/common/src/flow/Builders.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") diff --git a/kotlinx-coroutines-core/common/src/flow/Channels.kt b/kotlinx-coroutines-core/common/src/flow/Channels.kt index a9566628b4..481d057ebc 100644 --- a/kotlinx-coroutines-core/common/src/flow/Channels.kt +++ b/kotlinx-coroutines-core/common/src/flow/Channels.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") diff --git a/kotlinx-coroutines-core/common/src/flow/Flow.kt b/kotlinx-coroutines-core/common/src/flow/Flow.kt index 92006d469b..77836dc46e 100644 --- a/kotlinx-coroutines-core/common/src/flow/Flow.kt +++ b/kotlinx-coroutines-core/common/src/flow/Flow.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/flow/FlowCollector.kt b/kotlinx-coroutines-core/common/src/flow/FlowCollector.kt index 2877fe55e7..2110a82800 100644 --- a/kotlinx-coroutines-core/common/src/flow/FlowCollector.kt +++ b/kotlinx-coroutines-core/common/src/flow/FlowCollector.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow /** diff --git a/kotlinx-coroutines-core/common/src/flow/Migration.kt b/kotlinx-coroutines-core/common/src/flow/Migration.kt index e398740bbb..da36bf6c2e 100644 --- a/kotlinx-coroutines-core/common/src/flow/Migration.kt +++ b/kotlinx-coroutines-core/common/src/flow/Migration.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") @file:Suppress("unused", "DeprecatedCallableAddReplaceWith", "UNUSED_PARAMETER", "NO_EXPLICIT_RETURN_TYPE_IN_API_MODE") diff --git a/kotlinx-coroutines-core/common/src/flow/SharedFlow.kt b/kotlinx-coroutines-core/common/src/flow/SharedFlow.kt index 588560e2c3..8f8bdd59dd 100644 --- a/kotlinx-coroutines-core/common/src/flow/SharedFlow.kt +++ b/kotlinx-coroutines-core/common/src/flow/SharedFlow.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/flow/SharingStarted.kt b/kotlinx-coroutines-core/common/src/flow/SharingStarted.kt index 0554142408..c6c166c5c7 100644 --- a/kotlinx-coroutines-core/common/src/flow/SharingStarted.kt +++ b/kotlinx-coroutines-core/common/src/flow/SharingStarted.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/flow/StateFlow.kt b/kotlinx-coroutines-core/common/src/flow/StateFlow.kt index 2f3de1565e..6e95725e6b 100644 --- a/kotlinx-coroutines-core/common/src/flow/StateFlow.kt +++ b/kotlinx-coroutines-core/common/src/flow/StateFlow.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/flow/internal/AbstractSharedFlow.kt b/kotlinx-coroutines-core/common/src/flow/internal/AbstractSharedFlow.kt index 5dcf0d01ed..da239ff601 100644 --- a/kotlinx-coroutines-core/common/src/flow/internal/AbstractSharedFlow.kt +++ b/kotlinx-coroutines-core/common/src/flow/internal/AbstractSharedFlow.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.channels.* diff --git a/kotlinx-coroutines-core/common/src/flow/internal/ChannelFlow.kt b/kotlinx-coroutines-core/common/src/flow/internal/ChannelFlow.kt index 8610cf5a48..e00c1fdd61 100644 --- a/kotlinx-coroutines-core/common/src/flow/internal/ChannelFlow.kt +++ b/kotlinx-coroutines-core/common/src/flow/internal/ChannelFlow.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/flow/internal/Combine.kt b/kotlinx-coroutines-core/common/src/flow/internal/Combine.kt index 63ea55a585..eb82426760 100644 --- a/kotlinx-coroutines-core/common/src/flow/internal/Combine.kt +++ b/kotlinx-coroutines-core/common/src/flow/internal/Combine.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("UNCHECKED_CAST") // KT-32203 package kotlinx.coroutines.flow.internal diff --git a/kotlinx-coroutines-core/common/src/flow/internal/FlowCoroutine.kt b/kotlinx-coroutines-core/common/src/flow/internal/FlowCoroutine.kt index 9a81eefa2d..9510ee8d23 100644 --- a/kotlinx-coroutines-core/common/src/flow/internal/FlowCoroutine.kt +++ b/kotlinx-coroutines-core/common/src/flow/internal/FlowCoroutine.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/flow/internal/FlowExceptions.common.kt b/kotlinx-coroutines-core/common/src/flow/internal/FlowExceptions.common.kt index 6a6c369c75..999e117e7c 100644 --- a/kotlinx-coroutines-core/common/src/flow/internal/FlowExceptions.common.kt +++ b/kotlinx-coroutines-core/common/src/flow/internal/FlowExceptions.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/flow/internal/Merge.kt b/kotlinx-coroutines-core/common/src/flow/internal/Merge.kt index c18adba3b7..986a41bd06 100644 --- a/kotlinx-coroutines-core/common/src/flow/internal/Merge.kt +++ b/kotlinx-coroutines-core/common/src/flow/internal/Merge.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/flow/internal/NopCollector.kt b/kotlinx-coroutines-core/common/src/flow/internal/NopCollector.kt index a2d7f04f20..c4e68abe6d 100644 --- a/kotlinx-coroutines-core/common/src/flow/internal/NopCollector.kt +++ b/kotlinx-coroutines-core/common/src/flow/internal/NopCollector.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.flow.* diff --git a/kotlinx-coroutines-core/common/src/flow/internal/NullSurrogate.kt b/kotlinx-coroutines-core/common/src/flow/internal/NullSurrogate.kt index 7b59e2715c..230f466e2e 100644 --- a/kotlinx-coroutines-core/common/src/flow/internal/NullSurrogate.kt +++ b/kotlinx-coroutines-core/common/src/flow/internal/NullSurrogate.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/common/src/flow/internal/SafeCollector.common.kt b/kotlinx-coroutines-core/common/src/flow/internal/SafeCollector.common.kt index 68d34f264c..4e82ca65a7 100644 --- a/kotlinx-coroutines-core/common/src/flow/internal/SafeCollector.common.kt +++ b/kotlinx-coroutines-core/common/src/flow/internal/SafeCollector.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/flow/internal/SendingCollector.kt b/kotlinx-coroutines-core/common/src/flow/internal/SendingCollector.kt index 5188a969ca..a6a1557151 100644 --- a/kotlinx-coroutines-core/common/src/flow/internal/SendingCollector.kt +++ b/kotlinx-coroutines-core/common/src/flow/internal/SendingCollector.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/flow/operators/Context.kt b/kotlinx-coroutines-core/common/src/flow/operators/Context.kt index 8ed5606b83..99e2134132 100644 --- a/kotlinx-coroutines-core/common/src/flow/operators/Context.kt +++ b/kotlinx-coroutines-core/common/src/flow/operators/Context.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") diff --git a/kotlinx-coroutines-core/common/src/flow/operators/Delay.kt b/kotlinx-coroutines-core/common/src/flow/operators/Delay.kt index 9e53647d5f..a9e8e616b5 100644 --- a/kotlinx-coroutines-core/common/src/flow/operators/Delay.kt +++ b/kotlinx-coroutines-core/common/src/flow/operators/Delay.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") diff --git a/kotlinx-coroutines-core/common/src/flow/operators/Distinct.kt b/kotlinx-coroutines-core/common/src/flow/operators/Distinct.kt index 006d37e14e..78e4d71a89 100644 --- a/kotlinx-coroutines-core/common/src/flow/operators/Distinct.kt +++ b/kotlinx-coroutines-core/common/src/flow/operators/Distinct.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") diff --git a/kotlinx-coroutines-core/common/src/flow/operators/Emitters.kt b/kotlinx-coroutines-core/common/src/flow/operators/Emitters.kt index d83d4d3dfc..ceeb336392 100644 --- a/kotlinx-coroutines-core/common/src/flow/operators/Emitters.kt +++ b/kotlinx-coroutines-core/common/src/flow/operators/Emitters.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") @file:Suppress("UNCHECKED_CAST") diff --git a/kotlinx-coroutines-core/common/src/flow/operators/Errors.kt b/kotlinx-coroutines-core/common/src/flow/operators/Errors.kt index 30512f407d..7da73bf2cf 100644 --- a/kotlinx-coroutines-core/common/src/flow/operators/Errors.kt +++ b/kotlinx-coroutines-core/common/src/flow/operators/Errors.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") diff --git a/kotlinx-coroutines-core/common/src/flow/operators/Limit.kt b/kotlinx-coroutines-core/common/src/flow/operators/Limit.kt index 1b8abad000..3d489aa946 100644 --- a/kotlinx-coroutines-core/common/src/flow/operators/Limit.kt +++ b/kotlinx-coroutines-core/common/src/flow/operators/Limit.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") diff --git a/kotlinx-coroutines-core/common/src/flow/operators/Lint.kt b/kotlinx-coroutines-core/common/src/flow/operators/Lint.kt index d7fec3fec0..42b40c5909 100644 --- a/kotlinx-coroutines-core/common/src/flow/operators/Lint.kt +++ b/kotlinx-coroutines-core/common/src/flow/operators/Lint.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("unused", "INVISIBLE_REFERENCE", "INVISIBLE_MEMBER", "UNUSED_PARAMETER") package kotlinx.coroutines.flow diff --git a/kotlinx-coroutines-core/common/src/flow/operators/Merge.kt b/kotlinx-coroutines-core/common/src/flow/operators/Merge.kt index dfd08b8fe9..55c7f13037 100644 --- a/kotlinx-coroutines-core/common/src/flow/operators/Merge.kt +++ b/kotlinx-coroutines-core/common/src/flow/operators/Merge.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") @file:Suppress("unused") diff --git a/kotlinx-coroutines-core/common/src/flow/operators/Share.kt b/kotlinx-coroutines-core/common/src/flow/operators/Share.kt index 2b690e3c04..b4c499659c 100644 --- a/kotlinx-coroutines-core/common/src/flow/operators/Share.kt +++ b/kotlinx-coroutines-core/common/src/flow/operators/Share.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") diff --git a/kotlinx-coroutines-core/common/src/flow/operators/Transform.kt b/kotlinx-coroutines-core/common/src/flow/operators/Transform.kt index 4123aed0a3..2f43cfacc7 100644 --- a/kotlinx-coroutines-core/common/src/flow/operators/Transform.kt +++ b/kotlinx-coroutines-core/common/src/flow/operators/Transform.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") @file:Suppress("UNCHECKED_CAST") diff --git a/kotlinx-coroutines-core/common/src/flow/operators/Zip.kt b/kotlinx-coroutines-core/common/src/flow/operators/Zip.kt index 4998030cb0..3b9237eda8 100644 --- a/kotlinx-coroutines-core/common/src/flow/operators/Zip.kt +++ b/kotlinx-coroutines-core/common/src/flow/operators/Zip.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") @file:Suppress("UNCHECKED_CAST") diff --git a/kotlinx-coroutines-core/common/src/flow/terminal/Collect.kt b/kotlinx-coroutines-core/common/src/flow/terminal/Collect.kt index 98852c5825..5add0fde76 100644 --- a/kotlinx-coroutines-core/common/src/flow/terminal/Collect.kt +++ b/kotlinx-coroutines-core/common/src/flow/terminal/Collect.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") diff --git a/kotlinx-coroutines-core/common/src/flow/terminal/Collection.kt b/kotlinx-coroutines-core/common/src/flow/terminal/Collection.kt index c973da8973..33057124e9 100644 --- a/kotlinx-coroutines-core/common/src/flow/terminal/Collection.kt +++ b/kotlinx-coroutines-core/common/src/flow/terminal/Collection.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") diff --git a/kotlinx-coroutines-core/common/src/flow/terminal/Count.kt b/kotlinx-coroutines-core/common/src/flow/terminal/Count.kt index a15567e222..cfa11bce1c 100644 --- a/kotlinx-coroutines-core/common/src/flow/terminal/Count.kt +++ b/kotlinx-coroutines-core/common/src/flow/terminal/Count.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") diff --git a/kotlinx-coroutines-core/common/src/flow/terminal/Reduce.kt b/kotlinx-coroutines-core/common/src/flow/terminal/Reduce.kt index 557c095ade..f241196b72 100644 --- a/kotlinx-coroutines-core/common/src/flow/terminal/Reduce.kt +++ b/kotlinx-coroutines-core/common/src/flow/terminal/Reduce.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") @file:Suppress("UNCHECKED_CAST") diff --git a/kotlinx-coroutines-core/common/src/internal/Atomic.kt b/kotlinx-coroutines-core/common/src/internal/Atomic.kt index ff4320e0b3..60e06ec665 100644 --- a/kotlinx-coroutines-core/common/src/internal/Atomic.kt +++ b/kotlinx-coroutines-core/common/src/internal/Atomic.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("NO_EXPLICIT_VISIBILITY_IN_API_MODE") package kotlinx.coroutines.internal diff --git a/kotlinx-coroutines-core/common/src/internal/Concurrent.common.kt b/kotlinx-coroutines-core/common/src/internal/Concurrent.common.kt index c06fcaf7b2..1113be6f83 100644 --- a/kotlinx-coroutines-core/common/src/internal/Concurrent.common.kt +++ b/kotlinx-coroutines-core/common/src/internal/Concurrent.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal internal expect class ReentrantLock() { diff --git a/kotlinx-coroutines-core/common/src/internal/ConcurrentLinkedList.kt b/kotlinx-coroutines-core/common/src/internal/ConcurrentLinkedList.kt index ecfafcf439..8f9b13f4ab 100644 --- a/kotlinx-coroutines-core/common/src/internal/ConcurrentLinkedList.kt +++ b/kotlinx-coroutines-core/common/src/internal/ConcurrentLinkedList.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/internal/CoroutineExceptionHandlerImpl.common.kt b/kotlinx-coroutines-core/common/src/internal/CoroutineExceptionHandlerImpl.common.kt index 3f5925a3ee..25a3a2684d 100644 --- a/kotlinx-coroutines-core/common/src/internal/CoroutineExceptionHandlerImpl.common.kt +++ b/kotlinx-coroutines-core/common/src/internal/CoroutineExceptionHandlerImpl.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/internal/DispatchedContinuation.kt b/kotlinx-coroutines-core/common/src/internal/DispatchedContinuation.kt index 0241c8dfc4..e21f1ed456 100644 --- a/kotlinx-coroutines-core/common/src/internal/DispatchedContinuation.kt +++ b/kotlinx-coroutines-core/common/src/internal/DispatchedContinuation.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/internal/DispatchedTask.kt b/kotlinx-coroutines-core/common/src/internal/DispatchedTask.kt index 75b518caa2..92d8119d96 100644 --- a/kotlinx-coroutines-core/common/src/internal/DispatchedTask.kt +++ b/kotlinx-coroutines-core/common/src/internal/DispatchedTask.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/common/src/internal/InlineList.kt b/kotlinx-coroutines-core/common/src/internal/InlineList.kt index 61bf6d01ad..e2cae68d55 100644 --- a/kotlinx-coroutines-core/common/src/internal/InlineList.kt +++ b/kotlinx-coroutines-core/common/src/internal/InlineList.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("UNCHECKED_CAST") package kotlinx.coroutines.internal diff --git a/kotlinx-coroutines-core/common/src/internal/InternalAnnotations.common.kt b/kotlinx-coroutines-core/common/src/internal/InternalAnnotations.common.kt index e0a4f24595..21eb1ec0bf 100644 --- a/kotlinx-coroutines-core/common/src/internal/InternalAnnotations.common.kt +++ b/kotlinx-coroutines-core/common/src/internal/InternalAnnotations.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal // Ignore JRE requirements for animal-sniffer, compileOnly dependency diff --git a/kotlinx-coroutines-core/common/src/internal/LimitedDispatcher.kt b/kotlinx-coroutines-core/common/src/internal/LimitedDispatcher.kt index 374e53b7b4..0c8e0778b1 100644 --- a/kotlinx-coroutines-core/common/src/internal/LimitedDispatcher.kt +++ b/kotlinx-coroutines-core/common/src/internal/LimitedDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/internal/LocalAtomics.common.kt b/kotlinx-coroutines-core/common/src/internal/LocalAtomics.common.kt index 74848b2d7e..7124f74a49 100644 --- a/kotlinx-coroutines-core/common/src/internal/LocalAtomics.common.kt +++ b/kotlinx-coroutines-core/common/src/internal/LocalAtomics.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal /* diff --git a/kotlinx-coroutines-core/common/src/internal/LockFreeLinkedList.common.kt b/kotlinx-coroutines-core/common/src/internal/LockFreeLinkedList.common.kt index 121cdedc9c..456a3b78cb 100644 --- a/kotlinx-coroutines-core/common/src/internal/LockFreeLinkedList.common.kt +++ b/kotlinx-coroutines-core/common/src/internal/LockFreeLinkedList.common.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("NO_EXPLICIT_VISIBILITY_IN_API_MODE") package kotlinx.coroutines.internal diff --git a/kotlinx-coroutines-core/common/src/internal/LockFreeTaskQueue.kt b/kotlinx-coroutines-core/common/src/internal/LockFreeTaskQueue.kt index 10c5c830ac..b056bfd33a 100644 --- a/kotlinx-coroutines-core/common/src/internal/LockFreeTaskQueue.kt +++ b/kotlinx-coroutines-core/common/src/internal/LockFreeTaskQueue.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/internal/MainDispatcherFactory.kt b/kotlinx-coroutines-core/common/src/internal/MainDispatcherFactory.kt index 45872f179d..c05b183ed3 100644 --- a/kotlinx-coroutines-core/common/src/internal/MainDispatcherFactory.kt +++ b/kotlinx-coroutines-core/common/src/internal/MainDispatcherFactory.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/internal/OnUndeliveredElement.kt b/kotlinx-coroutines-core/common/src/internal/OnUndeliveredElement.kt index 1f1dea3d67..11d7d0bd78 100644 --- a/kotlinx-coroutines-core/common/src/internal/OnUndeliveredElement.kt +++ b/kotlinx-coroutines-core/common/src/internal/OnUndeliveredElement.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/internal/ProbesSupport.common.kt b/kotlinx-coroutines-core/common/src/internal/ProbesSupport.common.kt index a6d813619b..463599b8db 100644 --- a/kotlinx-coroutines-core/common/src/internal/ProbesSupport.common.kt +++ b/kotlinx-coroutines-core/common/src/internal/ProbesSupport.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/internal/Scopes.kt b/kotlinx-coroutines-core/common/src/internal/Scopes.kt index e0a183028d..7e561c83dc 100644 --- a/kotlinx-coroutines-core/common/src/internal/Scopes.kt +++ b/kotlinx-coroutines-core/common/src/internal/Scopes.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/internal/StackTraceRecovery.common.kt b/kotlinx-coroutines-core/common/src/internal/StackTraceRecovery.common.kt index ef0525e516..f5e0ab8f1d 100644 --- a/kotlinx-coroutines-core/common/src/internal/StackTraceRecovery.common.kt +++ b/kotlinx-coroutines-core/common/src/internal/StackTraceRecovery.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/internal/Symbol.kt b/kotlinx-coroutines-core/common/src/internal/Symbol.kt index b629951fbd..96e3480c1c 100644 --- a/kotlinx-coroutines-core/common/src/internal/Symbol.kt +++ b/kotlinx-coroutines-core/common/src/internal/Symbol.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlin.jvm.* diff --git a/kotlinx-coroutines-core/common/src/internal/Synchronized.common.kt b/kotlinx-coroutines-core/common/src/internal/Synchronized.common.kt index 7107945a55..2c50f3c4aa 100644 --- a/kotlinx-coroutines-core/common/src/internal/Synchronized.common.kt +++ b/kotlinx-coroutines-core/common/src/internal/Synchronized.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/internal/SystemProps.common.kt b/kotlinx-coroutines-core/common/src/internal/SystemProps.common.kt index 281c075b5e..61b7dc9bfa 100644 --- a/kotlinx-coroutines-core/common/src/internal/SystemProps.common.kt +++ b/kotlinx-coroutines-core/common/src/internal/SystemProps.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmName("SystemPropsKt") @file:JvmMultifileClass diff --git a/kotlinx-coroutines-core/common/src/internal/ThreadContext.common.kt b/kotlinx-coroutines-core/common/src/internal/ThreadContext.common.kt index 6d14e59230..c52d35c128 100644 --- a/kotlinx-coroutines-core/common/src/internal/ThreadContext.common.kt +++ b/kotlinx-coroutines-core/common/src/internal/ThreadContext.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/internal/ThreadLocal.common.kt b/kotlinx-coroutines-core/common/src/internal/ThreadLocal.common.kt index 73ec93f110..15622597d5 100644 --- a/kotlinx-coroutines-core/common/src/internal/ThreadLocal.common.kt +++ b/kotlinx-coroutines-core/common/src/internal/ThreadLocal.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal internal expect class CommonThreadLocal { diff --git a/kotlinx-coroutines-core/common/src/internal/ThreadSafeHeap.kt b/kotlinx-coroutines-core/common/src/internal/ThreadSafeHeap.kt index d05c1c7e78..c8d4cfe1af 100644 --- a/kotlinx-coroutines-core/common/src/internal/ThreadSafeHeap.kt +++ b/kotlinx-coroutines-core/common/src/internal/ThreadSafeHeap.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/intrinsics/Cancellable.kt b/kotlinx-coroutines-core/common/src/intrinsics/Cancellable.kt index f5b96a8d88..1ba8a71c0a 100644 --- a/kotlinx-coroutines-core/common/src/intrinsics/Cancellable.kt +++ b/kotlinx-coroutines-core/common/src/intrinsics/Cancellable.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.intrinsics import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/intrinsics/Undispatched.kt b/kotlinx-coroutines-core/common/src/intrinsics/Undispatched.kt index 4b11407092..3e086e338d 100644 --- a/kotlinx-coroutines-core/common/src/intrinsics/Undispatched.kt +++ b/kotlinx-coroutines-core/common/src/intrinsics/Undispatched.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.intrinsics import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/selects/OnTimeout.kt b/kotlinx-coroutines-core/common/src/selects/OnTimeout.kt index ba39181378..449972648d 100644 --- a/kotlinx-coroutines-core/common/src/selects/OnTimeout.kt +++ b/kotlinx-coroutines-core/common/src/selects/OnTimeout.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/selects/Select.kt b/kotlinx-coroutines-core/common/src/selects/Select.kt index 79acdbd1c2..638cc312ed 100644 --- a/kotlinx-coroutines-core/common/src/selects/Select.kt +++ b/kotlinx-coroutines-core/common/src/selects/Select.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/selects/SelectOld.kt b/kotlinx-coroutines-core/common/src/selects/SelectOld.kt index 85476d2ca3..e636a63233 100644 --- a/kotlinx-coroutines-core/common/src/selects/SelectOld.kt +++ b/kotlinx-coroutines-core/common/src/selects/SelectOld.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/selects/SelectUnbiased.kt b/kotlinx-coroutines-core/common/src/selects/SelectUnbiased.kt index a4b1e04341..e72c6ed6eb 100644 --- a/kotlinx-coroutines-core/common/src/selects/SelectUnbiased.kt +++ b/kotlinx-coroutines-core/common/src/selects/SelectUnbiased.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:OptIn(ExperimentalContracts::class) package kotlinx.coroutines.selects diff --git a/kotlinx-coroutines-core/common/src/selects/WhileSelect.kt b/kotlinx-coroutines-core/common/src/selects/WhileSelect.kt index ccda6568ae..43bb187d7a 100644 --- a/kotlinx-coroutines-core/common/src/selects/WhileSelect.kt +++ b/kotlinx-coroutines-core/common/src/selects/WhileSelect.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/src/sync/Mutex.kt b/kotlinx-coroutines-core/common/src/sync/Mutex.kt index 09c958ce7e..2bdad8c1a5 100644 --- a/kotlinx-coroutines-core/common/src/sync/Mutex.kt +++ b/kotlinx-coroutines-core/common/src/sync/Mutex.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.sync import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/src/sync/Semaphore.kt b/kotlinx-coroutines-core/common/src/sync/Semaphore.kt index 6d4aa7c9c7..54d1efab31 100644 --- a/kotlinx-coroutines-core/common/src/sync/Semaphore.kt +++ b/kotlinx-coroutines-core/common/src/sync/Semaphore.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.sync import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/test/AbstractCoroutineTest.kt b/kotlinx-coroutines-core/common/test/AbstractCoroutineTest.kt index ebe88ce156..0e491c6420 100644 --- a/kotlinx-coroutines-core/common/test/AbstractCoroutineTest.kt +++ b/kotlinx-coroutines-core/common/test/AbstractCoroutineTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/AsyncLazyTest.kt b/kotlinx-coroutines-core/common/test/AsyncLazyTest.kt index cd2401049e..3a9eb8fd69 100644 --- a/kotlinx-coroutines-core/common/test/AsyncLazyTest.kt +++ b/kotlinx-coroutines-core/common/test/AsyncLazyTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/AsyncTest.kt b/kotlinx-coroutines-core/common/test/AsyncTest.kt index 3fff252318..92e2e2a4e6 100644 --- a/kotlinx-coroutines-core/common/test/AsyncTest.kt +++ b/kotlinx-coroutines-core/common/test/AsyncTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED", "UNREACHABLE_CODE", "USELESS_IS_CHECK") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/AtomicCancellationCommonTest.kt b/kotlinx-coroutines-core/common/test/AtomicCancellationCommonTest.kt index 3881eb2779..c10e8b518e 100644 --- a/kotlinx-coroutines-core/common/test/AtomicCancellationCommonTest.kt +++ b/kotlinx-coroutines-core/common/test/AtomicCancellationCommonTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.selects.* diff --git a/kotlinx-coroutines-core/common/test/AwaitCancellationTest.kt b/kotlinx-coroutines-core/common/test/AwaitCancellationTest.kt index 2fe0c914e6..c32ca1177a 100644 --- a/kotlinx-coroutines-core/common/test/AwaitCancellationTest.kt +++ b/kotlinx-coroutines-core/common/test/AwaitCancellationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/common/test/AwaitTest.kt b/kotlinx-coroutines-core/common/test/AwaitTest.kt index 10d5b91995..c7edcd6f67 100644 --- a/kotlinx-coroutines-core/common/test/AwaitTest.kt +++ b/kotlinx-coroutines-core/common/test/AwaitTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/common/test/BuilderContractsTest.kt b/kotlinx-coroutines-core/common/test/BuilderContractsTest.kt index 5a96c54460..77213d3e97 100644 --- a/kotlinx-coroutines-core/common/test/BuilderContractsTest.kt +++ b/kotlinx-coroutines-core/common/test/BuilderContractsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.channels.* diff --git a/kotlinx-coroutines-core/common/test/CancellableContinuationHandlersTest.kt b/kotlinx-coroutines-core/common/test/CancellableContinuationHandlersTest.kt index 54bc18c17b..74e731f865 100644 --- a/kotlinx-coroutines-core/common/test/CancellableContinuationHandlersTest.kt +++ b/kotlinx-coroutines-core/common/test/CancellableContinuationHandlersTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/CancellableContinuationTest.kt b/kotlinx-coroutines-core/common/test/CancellableContinuationTest.kt index f9f610ceb5..cc09517e31 100644 --- a/kotlinx-coroutines-core/common/test/CancellableContinuationTest.kt +++ b/kotlinx-coroutines-core/common/test/CancellableContinuationTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/CancellableResumeTest.kt b/kotlinx-coroutines-core/common/test/CancellableResumeTest.kt index bff971961b..be2d6ef50a 100644 --- a/kotlinx-coroutines-core/common/test/CancellableResumeTest.kt +++ b/kotlinx-coroutines-core/common/test/CancellableResumeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/CancelledParentAttachTest.kt b/kotlinx-coroutines-core/common/test/CancelledParentAttachTest.kt index 9dd61b8012..f73beac5ca 100644 --- a/kotlinx-coroutines-core/common/test/CancelledParentAttachTest.kt +++ b/kotlinx-coroutines-core/common/test/CancelledParentAttachTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.channels.* diff --git a/kotlinx-coroutines-core/common/test/CompletableDeferredTest.kt b/kotlinx-coroutines-core/common/test/CompletableDeferredTest.kt index 1f3978d301..0d6f9b6521 100644 --- a/kotlinx-coroutines-core/common/test/CompletableDeferredTest.kt +++ b/kotlinx-coroutines-core/common/test/CompletableDeferredTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED", "DEPRECATION") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/CompletableJobTest.kt b/kotlinx-coroutines-core/common/test/CompletableJobTest.kt index 8b17e23556..0c484f00a9 100644 --- a/kotlinx-coroutines-core/common/test/CompletableJobTest.kt +++ b/kotlinx-coroutines-core/common/test/CompletableJobTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/common/test/CoroutineDispatcherOperatorFunInvokeTest.kt b/kotlinx-coroutines-core/common/test/CoroutineDispatcherOperatorFunInvokeTest.kt index e6b340cc62..d8f9cc73da 100644 --- a/kotlinx-coroutines-core/common/test/CoroutineDispatcherOperatorFunInvokeTest.kt +++ b/kotlinx-coroutines-core/common/test/CoroutineDispatcherOperatorFunInvokeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.ContinuationInterceptor diff --git a/kotlinx-coroutines-core/common/test/CoroutineExceptionHandlerTest.kt b/kotlinx-coroutines-core/common/test/CoroutineExceptionHandlerTest.kt index 95e93664b0..1857eaf36a 100644 --- a/kotlinx-coroutines-core/common/test/CoroutineExceptionHandlerTest.kt +++ b/kotlinx-coroutines-core/common/test/CoroutineExceptionHandlerTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/common/test/CoroutineScopeTest.kt b/kotlinx-coroutines-core/common/test/CoroutineScopeTest.kt index b678b03c7a..4c3a3f9600 100644 --- a/kotlinx-coroutines-core/common/test/CoroutineScopeTest.kt +++ b/kotlinx-coroutines-core/common/test/CoroutineScopeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("UNREACHABLE_CODE") package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/CoroutinesTest.kt b/kotlinx-coroutines-core/common/test/CoroutinesTest.kt index 534cfd61ce..ebc5843cd4 100644 --- a/kotlinx-coroutines-core/common/test/CoroutinesTest.kt +++ b/kotlinx-coroutines-core/common/test/CoroutinesTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/DelayDurationTest.kt b/kotlinx-coroutines-core/common/test/DelayDurationTest.kt index f05440998f..c52b3619d3 100644 --- a/kotlinx-coroutines-core/common/test/DelayDurationTest.kt +++ b/kotlinx-coroutines-core/common/test/DelayDurationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED", "DEPRECATION") // KT-21913 diff --git a/kotlinx-coroutines-core/common/test/DelayTest.kt b/kotlinx-coroutines-core/common/test/DelayTest.kt index 1b73146285..4e97d7bb26 100644 --- a/kotlinx-coroutines-core/common/test/DelayTest.kt +++ b/kotlinx-coroutines-core/common/test/DelayTest.kt @@ -1,8 +1,4 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED", "DEPRECATION") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/DispatchedContinuationTest.kt b/kotlinx-coroutines-core/common/test/DispatchedContinuationTest.kt index b69eb22e17..6f7672e3e6 100644 --- a/kotlinx-coroutines-core/common/test/DispatchedContinuationTest.kt +++ b/kotlinx-coroutines-core/common/test/DispatchedContinuationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/DurationToMillisTest.kt b/kotlinx-coroutines-core/common/test/DurationToMillisTest.kt index e2ea43dd3c..4815419f9b 100644 --- a/kotlinx-coroutines-core/common/test/DurationToMillisTest.kt +++ b/kotlinx-coroutines-core/common/test/DurationToMillisTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/common/test/EmptyContext.kt b/kotlinx-coroutines-core/common/test/EmptyContext.kt index 97efec34c9..61e595c559 100644 --- a/kotlinx-coroutines-core/common/test/EmptyContext.kt +++ b/kotlinx-coroutines-core/common/test/EmptyContext.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.intrinsics.* diff --git a/kotlinx-coroutines-core/common/test/ExperimentalDispatchModeTest.kt b/kotlinx-coroutines-core/common/test/ExperimentalDispatchModeTest.kt index 37e61824ee..8e83eec3e1 100644 --- a/kotlinx-coroutines-core/common/test/ExperimentalDispatchModeTest.kt +++ b/kotlinx-coroutines-core/common/test/ExperimentalDispatchModeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/common/test/FailedJobTest.kt b/kotlinx-coroutines-core/common/test/FailedJobTest.kt index e4d0fad2e8..0c7c7b3256 100644 --- a/kotlinx-coroutines-core/common/test/FailedJobTest.kt +++ b/kotlinx-coroutines-core/common/test/FailedJobTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/ImmediateYieldTest.kt b/kotlinx-coroutines-core/common/test/ImmediateYieldTest.kt index 3801b8ab07..53412beaed 100644 --- a/kotlinx-coroutines-core/common/test/ImmediateYieldTest.kt +++ b/kotlinx-coroutines-core/common/test/ImmediateYieldTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/JobExtensionsTest.kt b/kotlinx-coroutines-core/common/test/JobExtensionsTest.kt index b335926b1f..57a24ad6ee 100644 --- a/kotlinx-coroutines-core/common/test/JobExtensionsTest.kt +++ b/kotlinx-coroutines-core/common/test/JobExtensionsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/JobStatesTest.kt b/kotlinx-coroutines-core/common/test/JobStatesTest.kt index 739401f6a0..9c8f5920c8 100644 --- a/kotlinx-coroutines-core/common/test/JobStatesTest.kt +++ b/kotlinx-coroutines-core/common/test/JobStatesTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/JobTest.kt b/kotlinx-coroutines-core/common/test/JobTest.kt index 38895830b6..3ec836439d 100644 --- a/kotlinx-coroutines-core/common/test/JobTest.kt +++ b/kotlinx-coroutines-core/common/test/JobTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("DEPRECATION") package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/LaunchLazyTest.kt b/kotlinx-coroutines-core/common/test/LaunchLazyTest.kt index 1ed466d643..5f48c4187c 100644 --- a/kotlinx-coroutines-core/common/test/LaunchLazyTest.kt +++ b/kotlinx-coroutines-core/common/test/LaunchLazyTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/common/test/LimitedParallelismSharedTest.kt b/kotlinx-coroutines-core/common/test/LimitedParallelismSharedTest.kt index d01e85716b..938bcbd219 100644 --- a/kotlinx-coroutines-core/common/test/LimitedParallelismSharedTest.kt +++ b/kotlinx-coroutines-core/common/test/LimitedParallelismSharedTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/common/test/MainDispatcherTestBase.kt b/kotlinx-coroutines-core/common/test/MainDispatcherTestBase.kt index 3817602c50..c4b21cdc28 100644 --- a/kotlinx-coroutines-core/common/test/MainDispatcherTestBase.kt +++ b/kotlinx-coroutines-core/common/test/MainDispatcherTestBase.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/common/test/NonCancellableTest.kt b/kotlinx-coroutines-core/common/test/NonCancellableTest.kt index 07c3f9b725..f8e2da1fc6 100644 --- a/kotlinx-coroutines-core/common/test/NonCancellableTest.kt +++ b/kotlinx-coroutines-core/common/test/NonCancellableTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/common/test/ParentCancellationTest.kt b/kotlinx-coroutines-core/common/test/ParentCancellationTest.kt index 96c5cf3f4f..4a341fd6c7 100644 --- a/kotlinx-coroutines-core/common/test/ParentCancellationTest.kt +++ b/kotlinx-coroutines-core/common/test/ParentCancellationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/SupervisorTest.kt b/kotlinx-coroutines-core/common/test/SupervisorTest.kt index 535073e046..c58e95c5e3 100644 --- a/kotlinx-coroutines-core/common/test/SupervisorTest.kt +++ b/kotlinx-coroutines-core/common/test/SupervisorTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/TestBase.common.kt b/kotlinx-coroutines-core/common/test/TestBase.common.kt index 3b9aeefab6..6172bb8c64 100644 --- a/kotlinx-coroutines-core/common/test/TestBase.common.kt +++ b/kotlinx-coroutines-core/common/test/TestBase.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("unused") package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/UnconfinedTest.kt b/kotlinx-coroutines-core/common/test/UnconfinedTest.kt index 4f9cc9b11b..53c7e58a7a 100644 --- a/kotlinx-coroutines-core/common/test/UnconfinedTest.kt +++ b/kotlinx-coroutines-core/common/test/UnconfinedTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/common/test/UndispatchedResultTest.kt b/kotlinx-coroutines-core/common/test/UndispatchedResultTest.kt index 34b8164472..d29c0e40d3 100644 --- a/kotlinx-coroutines-core/common/test/UndispatchedResultTest.kt +++ b/kotlinx-coroutines-core/common/test/UndispatchedResultTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/WithContextTest.kt b/kotlinx-coroutines-core/common/test/WithContextTest.kt index 55127e5c0b..9eb7ddae60 100644 --- a/kotlinx-coroutines-core/common/test/WithContextTest.kt +++ b/kotlinx-coroutines-core/common/test/WithContextTest.kt @@ -1,8 +1,4 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-22237 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/WithTimeoutDurationTest.kt b/kotlinx-coroutines-core/common/test/WithTimeoutDurationTest.kt index 60e64f5830..0a60a64165 100644 --- a/kotlinx-coroutines-core/common/test/WithTimeoutDurationTest.kt +++ b/kotlinx-coroutines-core/common/test/WithTimeoutDurationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED", "UNREACHABLE_CODE") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/WithTimeoutOrNullDurationTest.kt b/kotlinx-coroutines-core/common/test/WithTimeoutOrNullDurationTest.kt index 1f9ad46f47..f62fc1f207 100644 --- a/kotlinx-coroutines-core/common/test/WithTimeoutOrNullDurationTest.kt +++ b/kotlinx-coroutines-core/common/test/WithTimeoutOrNullDurationTest.kt @@ -1,8 +1,4 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/WithTimeoutOrNullTest.kt b/kotlinx-coroutines-core/common/test/WithTimeoutOrNullTest.kt index 5ab8ae7df9..9f1316b48e 100644 --- a/kotlinx-coroutines-core/common/test/WithTimeoutOrNullTest.kt +++ b/kotlinx-coroutines-core/common/test/WithTimeoutOrNullTest.kt @@ -1,8 +1,4 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/WithTimeoutTest.kt b/kotlinx-coroutines-core/common/test/WithTimeoutTest.kt index 8462c96953..22ac2bf6b1 100644 --- a/kotlinx-coroutines-core/common/test/WithTimeoutTest.kt +++ b/kotlinx-coroutines-core/common/test/WithTimeoutTest.kt @@ -1,8 +1,4 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED", "UNREACHABLE_CODE") // KT-21913 package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/common/test/channels/BasicOperationsTest.kt b/kotlinx-coroutines-core/common/test/channels/BasicOperationsTest.kt index 1f9b6fa739..3f2a4f8a0e 100644 --- a/kotlinx-coroutines-core/common/test/channels/BasicOperationsTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/BasicOperationsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/BroadcastChannelFactoryTest.kt b/kotlinx-coroutines-core/common/test/channels/BroadcastChannelFactoryTest.kt index e27edcf6f7..ed7b3727a4 100644 --- a/kotlinx-coroutines-core/common/test/channels/BroadcastChannelFactoryTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/BroadcastChannelFactoryTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/BroadcastTest.kt b/kotlinx-coroutines-core/common/test/channels/BroadcastTest.kt index 4c392cbad8..8083cf0a67 100644 --- a/kotlinx-coroutines-core/common/test/channels/BroadcastTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/BroadcastTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("DEPRECATION") package kotlinx.coroutines.channels diff --git a/kotlinx-coroutines-core/common/test/channels/BufferedBroadcastChannelTest.kt b/kotlinx-coroutines-core/common/test/channels/BufferedBroadcastChannelTest.kt index fad6500805..894f140b5c 100644 --- a/kotlinx-coroutines-core/common/test/channels/BufferedBroadcastChannelTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/BufferedBroadcastChannelTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/BufferedChannelTest.kt b/kotlinx-coroutines-core/common/test/channels/BufferedChannelTest.kt index 0f7035214b..4269a4800b 100644 --- a/kotlinx-coroutines-core/common/test/channels/BufferedChannelTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/BufferedChannelTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/ChannelBufferOverflowTest.kt b/kotlinx-coroutines-core/common/test/channels/ChannelBufferOverflowTest.kt index 0b9a0fdbe4..12e1604792 100644 --- a/kotlinx-coroutines-core/common/test/channels/ChannelBufferOverflowTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/ChannelBufferOverflowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/ChannelFactoryTest.kt b/kotlinx-coroutines-core/common/test/channels/ChannelFactoryTest.kt index 706a2fdd0a..64f1459a58 100644 --- a/kotlinx-coroutines-core/common/test/channels/ChannelFactoryTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/ChannelFactoryTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/ChannelReceiveCatchingTest.kt b/kotlinx-coroutines-core/common/test/channels/ChannelReceiveCatchingTest.kt index 2341c62ebe..b0bdb690a7 100644 --- a/kotlinx-coroutines-core/common/test/channels/ChannelReceiveCatchingTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/ChannelReceiveCatchingTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/ChannelUndeliveredElementFailureTest.kt b/kotlinx-coroutines-core/common/test/channels/ChannelUndeliveredElementFailureTest.kt index 0faa79b3ae..bbe1cfb152 100644 --- a/kotlinx-coroutines-core/common/test/channels/ChannelUndeliveredElementFailureTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/ChannelUndeliveredElementFailureTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/ChannelUndeliveredElementTest.kt b/kotlinx-coroutines-core/common/test/channels/ChannelUndeliveredElementTest.kt index 3a99484630..9259178e07 100644 --- a/kotlinx-coroutines-core/common/test/channels/ChannelUndeliveredElementTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/ChannelUndeliveredElementTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/common/test/channels/ChannelsTest.kt b/kotlinx-coroutines-core/common/test/channels/ChannelsTest.kt index e40071b91e..8522de63ec 100644 --- a/kotlinx-coroutines-core/common/test/channels/ChannelsTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/ChannelsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("DEPRECATION") package kotlinx.coroutines.channels diff --git a/kotlinx-coroutines-core/common/test/channels/ConflatedBroadcastChannelTest.kt b/kotlinx-coroutines-core/common/test/channels/ConflatedBroadcastChannelTest.kt index a8c2a29c1b..1ff38b8999 100644 --- a/kotlinx-coroutines-core/common/test/channels/ConflatedBroadcastChannelTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/ConflatedBroadcastChannelTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/ConflatedChannelTest.kt b/kotlinx-coroutines-core/common/test/channels/ConflatedChannelTest.kt index 370fd5b9a2..43ffde47a5 100644 --- a/kotlinx-coroutines-core/common/test/channels/ConflatedChannelTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/ConflatedChannelTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/ConsumeTest.kt b/kotlinx-coroutines-core/common/test/channels/ConsumeTest.kt index c4683059c8..4b04185f66 100644 --- a/kotlinx-coroutines-core/common/test/channels/ConsumeTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/ConsumeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:OptIn(DelicateCoroutinesApi::class) package kotlinx.coroutines.channels diff --git a/kotlinx-coroutines-core/common/test/channels/ProduceConsumeTest.kt b/kotlinx-coroutines-core/common/test/channels/ProduceConsumeTest.kt index 5df0c7d6cb..5c8059dda6 100644 --- a/kotlinx-coroutines-core/common/test/channels/ProduceConsumeTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/ProduceConsumeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/ProduceTest.kt b/kotlinx-coroutines-core/common/test/channels/ProduceTest.kt index 61ef072622..8bfe144e29 100644 --- a/kotlinx-coroutines-core/common/test/channels/ProduceTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/ProduceTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/RendezvousChannelTest.kt b/kotlinx-coroutines-core/common/test/channels/RendezvousChannelTest.kt index c83813e40e..1e5fabe212 100644 --- a/kotlinx-coroutines-core/common/test/channels/RendezvousChannelTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/RendezvousChannelTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/SendReceiveStressTest.kt b/kotlinx-coroutines-core/common/test/channels/SendReceiveStressTest.kt index dcbb2d2f15..0abfb0b1ec 100644 --- a/kotlinx-coroutines-core/common/test/channels/SendReceiveStressTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/SendReceiveStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/TestBroadcastChannelKind.kt b/kotlinx-coroutines-core/common/test/channels/TestBroadcastChannelKind.kt index 94a488763f..0d23238da5 100644 --- a/kotlinx-coroutines-core/common/test/channels/TestBroadcastChannelKind.kt +++ b/kotlinx-coroutines-core/common/test/channels/TestBroadcastChannelKind.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels enum class TestBroadcastChannelKind { diff --git a/kotlinx-coroutines-core/common/test/channels/TestChannelKind.kt b/kotlinx-coroutines-core/common/test/channels/TestChannelKind.kt index 305c0eea7f..97562d4f02 100644 --- a/kotlinx-coroutines-core/common/test/channels/TestChannelKind.kt +++ b/kotlinx-coroutines-core/common/test/channels/TestChannelKind.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/channels/UnlimitedChannelTest.kt b/kotlinx-coroutines-core/common/test/channels/UnlimitedChannelTest.kt index 24b9d3d058..037c38bfdc 100644 --- a/kotlinx-coroutines-core/common/test/channels/UnlimitedChannelTest.kt +++ b/kotlinx-coroutines-core/common/test/channels/UnlimitedChannelTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/BuildersTest.kt b/kotlinx-coroutines-core/common/test/flow/BuildersTest.kt index e86a8fd9dd..52ac3e77b6 100644 --- a/kotlinx-coroutines-core/common/test/flow/BuildersTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/BuildersTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/FlowInvariantsTest.kt b/kotlinx-coroutines-core/common/test/flow/FlowInvariantsTest.kt index 5f39d3200d..1cfde56c3d 100644 --- a/kotlinx-coroutines-core/common/test/flow/FlowInvariantsTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/FlowInvariantsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/IdFlowTest.kt b/kotlinx-coroutines-core/common/test/flow/IdFlowTest.kt index a7299cc8d9..383c256a4a 100644 --- a/kotlinx-coroutines-core/common/test/flow/IdFlowTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/IdFlowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines.flow diff --git a/kotlinx-coroutines-core/common/test/flow/NamedDispatchers.kt b/kotlinx-coroutines-core/common/test/flow/NamedDispatchers.kt index 2459255c8d..754b3087ba 100644 --- a/kotlinx-coroutines-core/common/test/flow/NamedDispatchers.kt +++ b/kotlinx-coroutines-core/common/test/flow/NamedDispatchers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/SafeFlowTest.kt b/kotlinx-coroutines-core/common/test/flow/SafeFlowTest.kt index eaba11b950..05f956fc55 100644 --- a/kotlinx-coroutines-core/common/test/flow/SafeFlowTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/SafeFlowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/VirtualTime.kt b/kotlinx-coroutines-core/common/test/flow/VirtualTime.kt index bba5c6bd87..d36d40b921 100644 --- a/kotlinx-coroutines-core/common/test/flow/VirtualTime.kt +++ b/kotlinx-coroutines-core/common/test/flow/VirtualTime.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/channels/ChannelBuildersFlowTest.kt b/kotlinx-coroutines-core/common/test/flow/channels/ChannelBuildersFlowTest.kt index 410955ce4d..19d4e2c332 100644 --- a/kotlinx-coroutines-core/common/test/flow/channels/ChannelBuildersFlowTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/channels/ChannelBuildersFlowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/channels/ChannelFlowTest.kt b/kotlinx-coroutines-core/common/test/flow/channels/ChannelFlowTest.kt index f197a214f5..19bd878ce6 100644 --- a/kotlinx-coroutines-core/common/test/flow/channels/ChannelFlowTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/channels/ChannelFlowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/channels/FlowCallbackTest.kt b/kotlinx-coroutines-core/common/test/flow/channels/FlowCallbackTest.kt index cfbf242c35..5b9eabb1fb 100644 --- a/kotlinx-coroutines-core/common/test/flow/channels/FlowCallbackTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/channels/FlowCallbackTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines.flow diff --git a/kotlinx-coroutines-core/common/test/flow/internal/FlowScopeTest.kt b/kotlinx-coroutines-core/common/test/flow/internal/FlowScopeTest.kt index e866647930..22465ec865 100644 --- a/kotlinx-coroutines-core/common/test/flow/internal/FlowScopeTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/internal/FlowScopeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/BufferConflationTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/BufferConflationTest.kt index 7b66977226..798dcebfe4 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/BufferConflationTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/BufferConflationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/BufferTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/BufferTest.kt index 4432a2bd05..81d57021ce 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/BufferTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/BufferTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/CancellableTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/CancellableTest.kt index b1b14c4c40..90b0c17f7e 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/CancellableTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/CancellableTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.operators import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/CatchTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/CatchTest.kt index ad91e49898..16a4af27b6 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/CatchTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/CatchTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/CombineParametersTestBase.kt b/kotlinx-coroutines-core/common/test/flow/operators/CombineParametersTestBase.kt index 8c65ea4fe7..3b402ef9cf 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/CombineParametersTestBase.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/CombineParametersTestBase.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.operators import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/CombineTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/CombineTest.kt index 07457b2867..81cc90a1cc 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/CombineTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/CombineTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("UNCHECKED_CAST") package kotlinx.coroutines.flow.operators diff --git a/kotlinx-coroutines-core/common/test/flow/operators/ConflateTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/ConflateTest.kt index 264aba081c..7c85ff73d9 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/ConflateTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/ConflateTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.operators import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/DebounceTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/DebounceTest.kt index 79de173603..37cfae189b 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/DebounceTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/DebounceTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/DistinctUntilChangedTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/DistinctUntilChangedTest.kt index 68e7f66b9d..4721e81fb3 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/DistinctUntilChangedTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/DistinctUntilChangedTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/DropTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/DropTest.kt index dfa2827447..f6ff28aaa3 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/DropTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/DropTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/DropWhileTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/DropWhileTest.kt index 088954bc6b..9b0634b3fd 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/DropWhileTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/DropWhileTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/FilterTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/FilterTest.kt index f52416d823..028b1fce0c 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/FilterTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/FilterTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/FilterTrivialTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/FilterTrivialTest.kt index f41fe731bf..1975f5083c 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/FilterTrivialTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/FilterTrivialTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/FlatMapBaseTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/FlatMapBaseTest.kt index ca1fa25afa..7c8c0ca208 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/FlatMapBaseTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/FlatMapBaseTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/FlatMapConcatTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/FlatMapConcatTest.kt index 8bb54fd718..59ea47ce05 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/FlatMapConcatTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/FlatMapConcatTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/FlatMapLatestTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/FlatMapLatestTest.kt index ad0bda9e4e..817d6ebbb2 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/FlatMapLatestTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/FlatMapLatestTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/FlatMapMergeBaseTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/FlatMapMergeBaseTest.kt index f09db120a8..fe6138aed9 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/FlatMapMergeBaseTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/FlatMapMergeBaseTest.kt @@ -1,8 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/FlatMapMergeFastPathTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/FlatMapMergeFastPathTest.kt index f810221848..ad3236268f 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/FlatMapMergeFastPathTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/FlatMapMergeFastPathTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/FlatMapMergeTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/FlatMapMergeTest.kt index c2ce346d9b..2225ee3fa6 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/FlatMapMergeTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/FlatMapMergeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/FlattenConcatTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/FlattenConcatTest.kt index 4ec7cc3cd1..fbe714a2df 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/FlattenConcatTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/FlattenConcatTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/FlattenMergeTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/FlattenMergeTest.kt index c15f503c45..ee3804f382 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/FlattenMergeTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/FlattenMergeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/FlowContextOptimizationsTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/FlowContextOptimizationsTest.kt index 7194a70d15..94735c6050 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/FlowContextOptimizationsTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/FlowContextOptimizationsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/FlowOnTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/FlowOnTest.kt index 8fba8456e8..feb5a71e1c 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/FlowOnTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/FlowOnTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/IndexedTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/IndexedTest.kt index 53db88dbab..c9b847817d 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/IndexedTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/IndexedTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/LintTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/LintTest.kt index 9cf6cbb958..d884d9cd4d 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/LintTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/LintTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.operators import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/MapNotNullTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/MapNotNullTest.kt index d8bb480054..8eb766dbba 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/MapNotNullTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/MapNotNullTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/MapTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/MapTest.kt index 8c9398a684..63b538acab 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/MapTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/MapTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/MergeTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/MergeTest.kt index f084798487..2234c0c4ff 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/MergeTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/MergeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/OnCompletionTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/OnCompletionTest.kt index 0ff2e0b836..94f2302bba 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/OnCompletionTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/OnCompletionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/OnEachTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/OnEachTest.kt index 3c1ebfa005..30e0420506 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/OnEachTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/OnEachTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/OnEmptyTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/OnEmptyTest.kt index 3da166645b..e94b9b289a 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/OnEmptyTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/OnEmptyTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.operators import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/OnStartTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/OnStartTest.kt index 0443e56a2c..c91a5234fc 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/OnStartTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/OnStartTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/RetryTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/RetryTest.kt index e5dde1b7fc..e064efd75c 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/RetryTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/RetryTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/SampleTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/SampleTest.kt index 4e4272984b..1d031d4743 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/SampleTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/SampleTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.operators import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/ScanTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/ScanTest.kt index c6be36d01e..94d3e74c6d 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/ScanTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/ScanTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/TakeTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/TakeTest.kt index ea8939fed2..4c80235f75 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/TakeTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/TakeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/TakeWhileTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/TakeWhileTest.kt index c198356b5d..b050fe2fd3 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/TakeWhileTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/TakeWhileTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/TimeoutTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/TimeoutTest.kt index 3835714e54..d07c9cde6f 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/TimeoutTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/TimeoutTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.operators import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/TransformLatestTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/TransformLatestTest.kt index 8d3b40bb23..75d47b9e17 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/TransformLatestTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/TransformLatestTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/TransformTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/TransformTest.kt index feb359647d..b045e5d077 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/TransformTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/TransformTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/TransformWhileTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/TransformWhileTest.kt index df660103c3..fa7a754310 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/TransformWhileTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/TransformWhileTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/operators/ZipTest.kt b/kotlinx-coroutines-core/common/test/flow/operators/ZipTest.kt index 02dbfc40d9..c0cd3dc0b9 100644 --- a/kotlinx-coroutines-core/common/test/flow/operators/ZipTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/operators/ZipTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/sharing/ShareInBufferTest.kt b/kotlinx-coroutines-core/common/test/flow/sharing/ShareInBufferTest.kt index 9c6aed211a..036ea7c4e9 100644 --- a/kotlinx-coroutines-core/common/test/flow/sharing/ShareInBufferTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/sharing/ShareInBufferTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/sharing/ShareInConflationTest.kt b/kotlinx-coroutines-core/common/test/flow/sharing/ShareInConflationTest.kt index c19d52367b..c4c2b66c65 100644 --- a/kotlinx-coroutines-core/common/test/flow/sharing/ShareInConflationTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/sharing/ShareInConflationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/sharing/ShareInFusionTest.kt b/kotlinx-coroutines-core/common/test/flow/sharing/ShareInFusionTest.kt index 85a17ba0fe..9e1277e500 100644 --- a/kotlinx-coroutines-core/common/test/flow/sharing/ShareInFusionTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/sharing/ShareInFusionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/sharing/ShareInTest.kt b/kotlinx-coroutines-core/common/test/flow/sharing/ShareInTest.kt index 19b70032f3..414d708f47 100644 --- a/kotlinx-coroutines-core/common/test/flow/sharing/ShareInTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/sharing/ShareInTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/sharing/SharedFlowScenarioTest.kt b/kotlinx-coroutines-core/common/test/flow/sharing/SharedFlowScenarioTest.kt index 794553b482..056df9af17 100644 --- a/kotlinx-coroutines-core/common/test/flow/sharing/SharedFlowScenarioTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/sharing/SharedFlowScenarioTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/sharing/SharedFlowTest.kt b/kotlinx-coroutines-core/common/test/flow/sharing/SharedFlowTest.kt index bb36c0ef9a..eb72bb0648 100644 --- a/kotlinx-coroutines-core/common/test/flow/sharing/SharedFlowTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/sharing/SharedFlowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/sharing/SharingStartedTest.kt b/kotlinx-coroutines-core/common/test/flow/sharing/SharingStartedTest.kt index 496fb7f8ff..17b6254aac 100644 --- a/kotlinx-coroutines-core/common/test/flow/sharing/SharingStartedTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/sharing/SharingStartedTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/sharing/SharingStartedWhileSubscribedTest.kt b/kotlinx-coroutines-core/common/test/flow/sharing/SharingStartedWhileSubscribedTest.kt index da2f3e5f3f..3149e3a6a6 100644 --- a/kotlinx-coroutines-core/common/test/flow/sharing/SharingStartedWhileSubscribedTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/sharing/SharingStartedWhileSubscribedTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/sharing/StateFlowTest.kt b/kotlinx-coroutines-core/common/test/flow/sharing/StateFlowTest.kt index a77f091b4f..3500b7910a 100644 --- a/kotlinx-coroutines-core/common/test/flow/sharing/StateFlowTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/sharing/StateFlowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/sharing/StateInTest.kt b/kotlinx-coroutines-core/common/test/flow/sharing/StateInTest.kt index a27489bb4a..892fcd8f1c 100644 --- a/kotlinx-coroutines-core/common/test/flow/sharing/StateInTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/sharing/StateInTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/terminal/CollectLatestTest.kt b/kotlinx-coroutines-core/common/test/flow/terminal/CollectLatestTest.kt index 122420c600..df6cf4f211 100644 --- a/kotlinx-coroutines-core/common/test/flow/terminal/CollectLatestTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/terminal/CollectLatestTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/terminal/CountTest.kt b/kotlinx-coroutines-core/common/test/flow/terminal/CountTest.kt index 4a6f5ae673..fed726b896 100644 --- a/kotlinx-coroutines-core/common/test/flow/terminal/CountTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/terminal/CountTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/terminal/FirstTest.kt b/kotlinx-coroutines-core/common/test/flow/terminal/FirstTest.kt index fa7fc9cb6c..d38a8d62c1 100644 --- a/kotlinx-coroutines-core/common/test/flow/terminal/FirstTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/terminal/FirstTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/terminal/FoldTest.kt b/kotlinx-coroutines-core/common/test/flow/terminal/FoldTest.kt index 9a920f1d5f..5149a118c6 100644 --- a/kotlinx-coroutines-core/common/test/flow/terminal/FoldTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/terminal/FoldTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/terminal/LastTest.kt b/kotlinx-coroutines-core/common/test/flow/terminal/LastTest.kt index e7699ccc65..f235d5028a 100644 --- a/kotlinx-coroutines-core/common/test/flow/terminal/LastTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/terminal/LastTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/terminal/LaunchFlow.kt b/kotlinx-coroutines-core/common/test/flow/terminal/LaunchFlow.kt index ceefa73925..3130dfd134 100644 --- a/kotlinx-coroutines-core/common/test/flow/terminal/LaunchFlow.kt +++ b/kotlinx-coroutines-core/common/test/flow/terminal/LaunchFlow.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/terminal/LaunchInTest.kt b/kotlinx-coroutines-core/common/test/flow/terminal/LaunchInTest.kt index 6b04b02462..6d1d56b4a8 100644 --- a/kotlinx-coroutines-core/common/test/flow/terminal/LaunchInTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/terminal/LaunchInTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/terminal/ReduceTest.kt b/kotlinx-coroutines-core/common/test/flow/terminal/ReduceTest.kt index 8ba0b5efbc..0574c63ca7 100644 --- a/kotlinx-coroutines-core/common/test/flow/terminal/ReduceTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/terminal/ReduceTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/terminal/SingleTest.kt b/kotlinx-coroutines-core/common/test/flow/terminal/SingleTest.kt index 2c1277b1e1..3d6bf9e91a 100644 --- a/kotlinx-coroutines-core/common/test/flow/terminal/SingleTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/terminal/SingleTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/flow/terminal/ToCollectionTest.kt b/kotlinx-coroutines-core/common/test/flow/terminal/ToCollectionTest.kt index cfcbb5218b..7cce5cfec6 100644 --- a/kotlinx-coroutines-core/common/test/flow/terminal/ToCollectionTest.kt +++ b/kotlinx-coroutines-core/common/test/flow/terminal/ToCollectionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/selects/SelectBiasTest.kt b/kotlinx-coroutines-core/common/test/selects/SelectBiasTest.kt index ec88fb5eb0..b23169ab03 100644 --- a/kotlinx-coroutines-core/common/test/selects/SelectBiasTest.kt +++ b/kotlinx-coroutines-core/common/test/selects/SelectBiasTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/selects/SelectBufferedChannelTest.kt b/kotlinx-coroutines-core/common/test/selects/SelectBufferedChannelTest.kt index 6bb8049e54..a8ddd13036 100644 --- a/kotlinx-coroutines-core/common/test/selects/SelectBufferedChannelTest.kt +++ b/kotlinx-coroutines-core/common/test/selects/SelectBufferedChannelTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/selects/SelectDeferredTest.kt b/kotlinx-coroutines-core/common/test/selects/SelectDeferredTest.kt index b1c07bab37..077e5d0536 100644 --- a/kotlinx-coroutines-core/common/test/selects/SelectDeferredTest.kt +++ b/kotlinx-coroutines-core/common/test/selects/SelectDeferredTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines.selects diff --git a/kotlinx-coroutines-core/common/test/selects/SelectJobTest.kt b/kotlinx-coroutines-core/common/test/selects/SelectJobTest.kt index 099a8741d5..82448f1a9a 100644 --- a/kotlinx-coroutines-core/common/test/selects/SelectJobTest.kt +++ b/kotlinx-coroutines-core/common/test/selects/SelectJobTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/selects/SelectLoopTest.kt b/kotlinx-coroutines-core/common/test/selects/SelectLoopTest.kt index ba8f56ad4c..e7a8ea08cf 100644 --- a/kotlinx-coroutines-core/common/test/selects/SelectLoopTest.kt +++ b/kotlinx-coroutines-core/common/test/selects/SelectLoopTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines.selects diff --git a/kotlinx-coroutines-core/common/test/selects/SelectMutexTest.kt b/kotlinx-coroutines-core/common/test/selects/SelectMutexTest.kt index 6f4c9e13af..14a49c6d1e 100644 --- a/kotlinx-coroutines-core/common/test/selects/SelectMutexTest.kt +++ b/kotlinx-coroutines-core/common/test/selects/SelectMutexTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/selects/SelectOldTest.kt b/kotlinx-coroutines-core/common/test/selects/SelectOldTest.kt index 34694fdea4..493beaf52b 100644 --- a/kotlinx-coroutines-core/common/test/selects/SelectOldTest.kt +++ b/kotlinx-coroutines-core/common/test/selects/SelectOldTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/selects/SelectRendezvousChannelTest.kt b/kotlinx-coroutines-core/common/test/selects/SelectRendezvousChannelTest.kt index f3c5b4f366..561ad4c6d6 100644 --- a/kotlinx-coroutines-core/common/test/selects/SelectRendezvousChannelTest.kt +++ b/kotlinx-coroutines-core/common/test/selects/SelectRendezvousChannelTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("NAMED_ARGUMENTS_NOT_ALLOWED") // KT-21913 package kotlinx.coroutines.selects diff --git a/kotlinx-coroutines-core/common/test/selects/SelectTimeoutDurationTest.kt b/kotlinx-coroutines-core/common/test/selects/SelectTimeoutDurationTest.kt index 62e62e5f2c..23813d3a63 100644 --- a/kotlinx-coroutines-core/common/test/selects/SelectTimeoutDurationTest.kt +++ b/kotlinx-coroutines-core/common/test/selects/SelectTimeoutDurationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/selects/SelectTimeoutTest.kt b/kotlinx-coroutines-core/common/test/selects/SelectTimeoutTest.kt index fbfb9c05cb..cf7f76c07e 100644 --- a/kotlinx-coroutines-core/common/test/selects/SelectTimeoutTest.kt +++ b/kotlinx-coroutines-core/common/test/selects/SelectTimeoutTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/selects/SelectUnlimitedChannelTest.kt b/kotlinx-coroutines-core/common/test/selects/SelectUnlimitedChannelTest.kt index 081c9183aa..d65f7cf57e 100644 --- a/kotlinx-coroutines-core/common/test/selects/SelectUnlimitedChannelTest.kt +++ b/kotlinx-coroutines-core/common/test/selects/SelectUnlimitedChannelTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/common/test/sync/MutexTest.kt b/kotlinx-coroutines-core/common/test/sync/MutexTest.kt index a9a62b6caf..cb4c29153f 100644 --- a/kotlinx-coroutines-core/common/test/sync/MutexTest.kt +++ b/kotlinx-coroutines-core/common/test/sync/MutexTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.sync import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/concurrent/src/Builders.concurrent.kt b/kotlinx-coroutines-core/concurrent/src/Builders.concurrent.kt index 8a6c09231b..525fc2ee75 100644 --- a/kotlinx-coroutines-core/concurrent/src/Builders.concurrent.kt +++ b/kotlinx-coroutines-core/concurrent/src/Builders.concurrent.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/concurrent/src/CompletionHandler.kt b/kotlinx-coroutines-core/concurrent/src/CompletionHandler.kt index 4835f7968e..4737112e4f 100644 --- a/kotlinx-coroutines-core/concurrent/src/CompletionHandler.kt +++ b/kotlinx-coroutines-core/concurrent/src/CompletionHandler.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/concurrent/src/Dispatchers.kt b/kotlinx-coroutines-core/concurrent/src/Dispatchers.kt index 8a937e38fc..aadca2fc9e 100644 --- a/kotlinx-coroutines-core/concurrent/src/Dispatchers.kt +++ b/kotlinx-coroutines-core/concurrent/src/Dispatchers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines /** diff --git a/kotlinx-coroutines-core/concurrent/src/MultithreadedDispatchers.common.kt b/kotlinx-coroutines-core/concurrent/src/MultithreadedDispatchers.common.kt index 45c5de70bb..072432c0e3 100644 --- a/kotlinx-coroutines-core/concurrent/src/MultithreadedDispatchers.common.kt +++ b/kotlinx-coroutines-core/concurrent/src/MultithreadedDispatchers.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("ThreadPoolDispatcherKt") package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/concurrent/src/internal/LockFreeLinkedList.kt b/kotlinx-coroutines-core/concurrent/src/internal/LockFreeLinkedList.kt index 0af2f6db9c..126629867c 100644 --- a/kotlinx-coroutines-core/concurrent/src/internal/LockFreeLinkedList.kt +++ b/kotlinx-coroutines-core/concurrent/src/internal/LockFreeLinkedList.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("NO_EXPLICIT_VISIBILITY_IN_API_MODE") package kotlinx.coroutines.internal diff --git a/kotlinx-coroutines-core/concurrent/src/internal/OnDemandAllocatingPool.kt b/kotlinx-coroutines-core/concurrent/src/internal/OnDemandAllocatingPool.kt index 1c2beff283..8c21159224 100644 --- a/kotlinx-coroutines-core/concurrent/src/internal/OnDemandAllocatingPool.kt +++ b/kotlinx-coroutines-core/concurrent/src/internal/OnDemandAllocatingPool.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/concurrent/test/AbstractDispatcherConcurrencyTest.kt b/kotlinx-coroutines-core/concurrent/test/AbstractDispatcherConcurrencyTest.kt index 7dc500f556..ac56f9964b 100644 --- a/kotlinx-coroutines-core/concurrent/test/AbstractDispatcherConcurrencyTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/AbstractDispatcherConcurrencyTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines import kotlinx.coroutines.channels.* diff --git a/kotlinx-coroutines-core/concurrent/test/AtomicCancellationTest.kt b/kotlinx-coroutines-core/concurrent/test/AtomicCancellationTest.kt index 7bbd7ebec7..6523686969 100644 --- a/kotlinx-coroutines-core/concurrent/test/AtomicCancellationTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/AtomicCancellationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.channels.* diff --git a/kotlinx-coroutines-core/concurrent/test/CommonThreadLocalTest.kt b/kotlinx-coroutines-core/concurrent/test/CommonThreadLocalTest.kt index 598a96cc19..3dad74e7d7 100644 --- a/kotlinx-coroutines-core/concurrent/test/CommonThreadLocalTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/CommonThreadLocalTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.exceptions.* diff --git a/kotlinx-coroutines-core/concurrent/test/ConcurrentExceptionsStressTest.kt b/kotlinx-coroutines-core/concurrent/test/ConcurrentExceptionsStressTest.kt index c2ffc16bed..9515a38798 100644 --- a/kotlinx-coroutines-core/concurrent/test/ConcurrentExceptionsStressTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/ConcurrentExceptionsStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.exceptions.* diff --git a/kotlinx-coroutines-core/concurrent/test/ConcurrentTestUtilities.common.kt b/kotlinx-coroutines-core/concurrent/test/ConcurrentTestUtilities.common.kt index 3fe230bcd4..8cc7f939bf 100644 --- a/kotlinx-coroutines-core/concurrent/test/ConcurrentTestUtilities.common.kt +++ b/kotlinx-coroutines-core/concurrent/test/ConcurrentTestUtilities.common.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/concurrent/test/DefaultDispatchersConcurrencyTest.kt b/kotlinx-coroutines-core/concurrent/test/DefaultDispatchersConcurrencyTest.kt index 66dfd07ab0..c231bb178e 100644 --- a/kotlinx-coroutines-core/concurrent/test/DefaultDispatchersConcurrencyTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/DefaultDispatchersConcurrencyTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines class DefaultDispatcherConcurrencyTest : AbstractDispatcherConcurrencyTest() { diff --git a/kotlinx-coroutines-core/concurrent/test/JobStructuredJoinStressTest.kt b/kotlinx-coroutines-core/concurrent/test/JobStructuredJoinStressTest.kt index 4b5c952d74..fb52662f71 100644 --- a/kotlinx-coroutines-core/concurrent/test/JobStructuredJoinStressTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/JobStructuredJoinStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/concurrent/test/LimitedParallelismConcurrentTest.kt b/kotlinx-coroutines-core/concurrent/test/LimitedParallelismConcurrentTest.kt index ba7e67cad8..cb4c598e1a 100644 --- a/kotlinx-coroutines-core/concurrent/test/LimitedParallelismConcurrentTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/LimitedParallelismConcurrentTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/concurrent/test/MultithreadedDispatcherStressTest.kt b/kotlinx-coroutines-core/concurrent/test/MultithreadedDispatcherStressTest.kt index 8eb9cdf189..9445637078 100644 --- a/kotlinx-coroutines-core/concurrent/test/MultithreadedDispatcherStressTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/MultithreadedDispatcherStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/concurrent/test/RunBlockingTest.kt b/kotlinx-coroutines-core/concurrent/test/RunBlockingTest.kt index f484476152..fae433a712 100644 --- a/kotlinx-coroutines-core/concurrent/test/RunBlockingTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/RunBlockingTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines import kotlinx.coroutines.exceptions.* diff --git a/kotlinx-coroutines-core/concurrent/test/channels/BroadcastChannelSubStressTest.kt b/kotlinx-coroutines-core/concurrent/test/channels/BroadcastChannelSubStressTest.kt index 245a80c222..70635030f1 100644 --- a/kotlinx-coroutines-core/concurrent/test/channels/BroadcastChannelSubStressTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/channels/BroadcastChannelSubStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/concurrent/test/channels/ChannelCancelUndeliveredElementStressTest.kt b/kotlinx-coroutines-core/concurrent/test/channels/ChannelCancelUndeliveredElementStressTest.kt index 1cf7d8a17d..4177138755 100644 --- a/kotlinx-coroutines-core/concurrent/test/channels/ChannelCancelUndeliveredElementStressTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/channels/ChannelCancelUndeliveredElementStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/concurrent/test/channels/ConflatedBroadcastChannelNotifyStressTest.kt b/kotlinx-coroutines-core/concurrent/test/channels/ConflatedBroadcastChannelNotifyStressTest.kt index d9ec7ad582..825b99dfff 100644 --- a/kotlinx-coroutines-core/concurrent/test/channels/ConflatedBroadcastChannelNotifyStressTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/channels/ConflatedBroadcastChannelNotifyStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/concurrent/test/channels/TrySendBlockingTest.kt b/kotlinx-coroutines-core/concurrent/test/channels/TrySendBlockingTest.kt index 77c651835a..674d588f81 100644 --- a/kotlinx-coroutines-core/concurrent/test/channels/TrySendBlockingTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/channels/TrySendBlockingTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/concurrent/test/flow/CombineStressTest.kt b/kotlinx-coroutines-core/concurrent/test/flow/CombineStressTest.kt index ea6f96bb2c..a284f44b32 100644 --- a/kotlinx-coroutines-core/concurrent/test/flow/CombineStressTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/flow/CombineStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/concurrent/test/flow/FlowCancellationTest.kt b/kotlinx-coroutines-core/concurrent/test/flow/FlowCancellationTest.kt index 8680ff7d53..03345872cf 100644 --- a/kotlinx-coroutines-core/concurrent/test/flow/FlowCancellationTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/flow/FlowCancellationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/concurrent/test/flow/StateFlowCommonStressTest.kt b/kotlinx-coroutines-core/concurrent/test/flow/StateFlowCommonStressTest.kt index abd191e5aa..9490e46792 100644 --- a/kotlinx-coroutines-core/concurrent/test/flow/StateFlowCommonStressTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/flow/StateFlowCommonStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/concurrent/test/flow/StateFlowUpdateCommonTest.kt b/kotlinx-coroutines-core/concurrent/test/flow/StateFlowUpdateCommonTest.kt index 8c75b46175..ad4d792059 100644 --- a/kotlinx-coroutines-core/concurrent/test/flow/StateFlowUpdateCommonTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/flow/StateFlowUpdateCommonTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/concurrent/test/selects/SelectChannelStressTest.kt b/kotlinx-coroutines-core/concurrent/test/selects/SelectChannelStressTest.kt index a5bf90ac40..a5d9dd467c 100644 --- a/kotlinx-coroutines-core/concurrent/test/selects/SelectChannelStressTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/selects/SelectChannelStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/concurrent/test/selects/SelectMutexStressTest.kt b/kotlinx-coroutines-core/concurrent/test/selects/SelectMutexStressTest.kt index 9395a98ba7..021bf02ef9 100644 --- a/kotlinx-coroutines-core/concurrent/test/selects/SelectMutexStressTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/selects/SelectMutexStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/concurrent/test/sync/MutexStressTest.kt b/kotlinx-coroutines-core/concurrent/test/sync/MutexStressTest.kt index 77fa7bf1b9..30b1379a0f 100644 --- a/kotlinx-coroutines-core/concurrent/test/sync/MutexStressTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/sync/MutexStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.sync import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/concurrent/test/sync/SemaphoreStressTest.kt b/kotlinx-coroutines-core/concurrent/test/sync/SemaphoreStressTest.kt index 9a3d25bcdd..b0db068121 100644 --- a/kotlinx-coroutines-core/concurrent/test/sync/SemaphoreStressTest.kt +++ b/kotlinx-coroutines-core/concurrent/test/sync/SemaphoreStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.sync import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jdk8/src/future/Future.kt b/kotlinx-coroutines-core/jdk8/src/future/Future.kt index f7b4fdca0d..ad2adbbe97 100644 --- a/kotlinx-coroutines-core/jdk8/src/future/Future.kt +++ b/kotlinx-coroutines-core/jdk8/src/future/Future.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.future import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jdk8/src/stream/Stream.kt b/kotlinx-coroutines-core/jdk8/src/stream/Stream.kt index b0d72de893..bbbac1f237 100644 --- a/kotlinx-coroutines-core/jdk8/src/stream/Stream.kt +++ b/kotlinx-coroutines-core/jdk8/src/stream/Stream.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.stream import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jdk8/src/time/Time.kt b/kotlinx-coroutines-core/jdk8/src/time/Time.kt index 78cf6e5305..3bb1d054e6 100644 --- a/kotlinx-coroutines-core/jdk8/src/time/Time.kt +++ b/kotlinx-coroutines-core/jdk8/src/time/Time.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:OptIn(ExperimentalContracts::class) package kotlinx.coroutines.time diff --git a/kotlinx-coroutines-core/js/src/CompletionHandler.kt b/kotlinx-coroutines-core/js/src/CompletionHandler.kt index 2ff1070222..06fec14918 100644 --- a/kotlinx-coroutines-core/js/src/CompletionHandler.kt +++ b/kotlinx-coroutines-core/js/src/CompletionHandler.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/js/src/CoroutineContext.kt b/kotlinx-coroutines-core/js/src/CoroutineContext.kt index 2d80a90730..3156dca4f4 100644 --- a/kotlinx-coroutines-core/js/src/CoroutineContext.kt +++ b/kotlinx-coroutines-core/js/src/CoroutineContext.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.browser.* diff --git a/kotlinx-coroutines-core/js/src/Debug.kt b/kotlinx-coroutines-core/js/src/Debug.kt index 7655b54389..d36d673283 100644 --- a/kotlinx-coroutines-core/js/src/Debug.kt +++ b/kotlinx-coroutines-core/js/src/Debug.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines private var counter = 0 diff --git a/kotlinx-coroutines-core/js/src/JSDispatcher.kt b/kotlinx-coroutines-core/js/src/JSDispatcher.kt index c94985b1c8..f547c154b0 100644 --- a/kotlinx-coroutines-core/js/src/JSDispatcher.kt +++ b/kotlinx-coroutines-core/js/src/JSDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.w3c.dom.* diff --git a/kotlinx-coroutines-core/js/src/Promise.kt b/kotlinx-coroutines-core/js/src/Promise.kt index 336a3883b3..fe4940e87e 100644 --- a/kotlinx-coroutines-core/js/src/Promise.kt +++ b/kotlinx-coroutines-core/js/src/Promise.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/js/src/Window.kt b/kotlinx-coroutines-core/js/src/Window.kt index 7e9932834f..7fea6f3092 100644 --- a/kotlinx-coroutines-core/js/src/Window.kt +++ b/kotlinx-coroutines-core/js/src/Window.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.w3c.dom.Window diff --git a/kotlinx-coroutines-core/js/src/internal/CopyOnWriteList.kt b/kotlinx-coroutines-core/js/src/internal/CopyOnWriteList.kt index 335e35d3b7..26ad530a9e 100644 --- a/kotlinx-coroutines-core/js/src/internal/CopyOnWriteList.kt +++ b/kotlinx-coroutines-core/js/src/internal/CopyOnWriteList.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal /** diff --git a/kotlinx-coroutines-core/js/src/internal/CoroutineExceptionHandlerImpl.kt b/kotlinx-coroutines-core/js/src/internal/CoroutineExceptionHandlerImpl.kt index 097f4bb607..b3c09e7c38 100644 --- a/kotlinx-coroutines-core/js/src/internal/CoroutineExceptionHandlerImpl.kt +++ b/kotlinx-coroutines-core/js/src/internal/CoroutineExceptionHandlerImpl.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/js/test/PromiseTest.kt b/kotlinx-coroutines-core/js/test/PromiseTest.kt index 6049a908cf..4d309d551d 100644 --- a/kotlinx-coroutines-core/js/test/PromiseTest.kt +++ b/kotlinx-coroutines-core/js/test/PromiseTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.js.* diff --git a/kotlinx-coroutines-core/js/test/TestBase.kt b/kotlinx-coroutines-core/js/test/TestBase.kt index 83f6cfd67d..7a3c6effb6 100644 --- a/kotlinx-coroutines-core/js/test/TestBase.kt +++ b/kotlinx-coroutines-core/js/test/TestBase.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.js.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/CloseableCoroutineDispatcher.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/CloseableCoroutineDispatcher.kt index 0e239a42f7..81e0c5d8c3 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/CloseableCoroutineDispatcher.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/CloseableCoroutineDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines public actual abstract class CloseableCoroutineDispatcher actual constructor() : CoroutineDispatcher() { diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/Dispatchers.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/Dispatchers.kt index 622344b577..ca74fbae76 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/Dispatchers.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/Dispatchers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/EventLoop.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/EventLoop.kt index 13c336969b..90549eecf4 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/EventLoop.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/EventLoop.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/Exceptions.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/Exceptions.kt index 30c5b26bbb..c6173afc26 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/Exceptions.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/Exceptions.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines /** diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/Runnable.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/Runnable.kt index b8e6980b22..1a9e0ae7a0 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/Runnable.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/Runnable.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines /** diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/SchedulerTask.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/SchedulerTask.kt index f8569ba505..111a9fc5e1 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/SchedulerTask.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/SchedulerTask.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines internal actual abstract class SchedulerTask : Runnable diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/flow/internal/FlowExceptions.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/flow/internal/FlowExceptions.kt index 000395ea7b..722911127e 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/flow/internal/FlowExceptions.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/flow/internal/FlowExceptions.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/flow/internal/SafeCollector.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/flow/internal/SafeCollector.kt index 483eee0c04..ded11e22f5 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/flow/internal/SafeCollector.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/flow/internal/SafeCollector.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/Concurrent.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/Concurrent.kt index 6272679e3f..c692dfcb9d 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/Concurrent.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/Concurrent.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal internal actual typealias ReentrantLock = NoOpLock diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/CoroutineExceptionHandlerImpl.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/CoroutineExceptionHandlerImpl.kt index 0612922edd..d664ce6406 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/CoroutineExceptionHandlerImpl.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/CoroutineExceptionHandlerImpl.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/JSDispatcher.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/JSDispatcher.kt index b93c0b35f0..4fa3f44f20 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/JSDispatcher.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/JSDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/LinkedList.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/LinkedList.kt index c4b1fddd03..8d68f8bf16 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/LinkedList.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/LinkedList.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("unused", "NO_EXPLICIT_RETURN_TYPE_IN_API_MODE", "NO_EXPLICIT_VISIBILITY_IN_API_MODE") package kotlinx.coroutines.internal diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/LocalAtomics.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/LocalAtomics.kt index 643fe85d36..e0e1bee56b 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/LocalAtomics.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/LocalAtomics.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal internal actual class LocalAtomicInt actual constructor(private var value: Int) { diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/ProbesSupport.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/ProbesSupport.kt index 47d3fdbac9..00581f1c91 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/ProbesSupport.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/ProbesSupport.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/StackTraceRecovery.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/StackTraceRecovery.kt index 2fb9527d68..7003a24fa2 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/StackTraceRecovery.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/StackTraceRecovery.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/Synchronized.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/Synchronized.kt index 91c422f237..e828f67588 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/Synchronized.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/Synchronized.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/SystemProps.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/SystemProps.kt index 4fb334ed16..accc247d37 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/SystemProps.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/SystemProps.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal internal actual fun systemProp(propertyName: String): String? = null diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/ThreadContext.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/ThreadContext.kt index 2370e42ff4..3f56f99d6c 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/ThreadContext.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/ThreadContext.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/ThreadLocal.kt b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/ThreadLocal.kt index 8800e281e3..94eecfa0ee 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/src/internal/ThreadLocal.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/src/internal/ThreadLocal.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal internal actual class CommonThreadLocal { diff --git a/kotlinx-coroutines-core/jsAndWasmShared/test/ImmediateDispatcherTest.kt b/kotlinx-coroutines-core/jsAndWasmShared/test/ImmediateDispatcherTest.kt index ac249560b9..e5322ee40b 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/test/ImmediateDispatcherTest.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/test/ImmediateDispatcherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/test/MessageQueueTest.kt b/kotlinx-coroutines-core/jsAndWasmShared/test/MessageQueueTest.kt index 7ce73804f7..5bf4d2db55 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/test/MessageQueueTest.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/test/MessageQueueTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/test/SetTimeoutDispatcherTest.kt b/kotlinx-coroutines-core/jsAndWasmShared/test/SetTimeoutDispatcherTest.kt index 78700776eb..97f303e14d 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/test/SetTimeoutDispatcherTest.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/test/SetTimeoutDispatcherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/jsAndWasmShared/test/internal/LinkedListTest.kt b/kotlinx-coroutines-core/jsAndWasmShared/test/internal/LinkedListTest.kt index 6c1fddfc5f..04b70065e9 100644 --- a/kotlinx-coroutines-core/jsAndWasmShared/test/internal/LinkedListTest.kt +++ b/kotlinx-coroutines-core/jsAndWasmShared/test/internal/LinkedListTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlin.test.Test diff --git a/kotlinx-coroutines-core/jvm/src/AbstractTimeSource.kt b/kotlinx-coroutines-core/jvm/src/AbstractTimeSource.kt index 3f7ac67537..ed86f3a55e 100644 --- a/kotlinx-coroutines-core/jvm/src/AbstractTimeSource.kt +++ b/kotlinx-coroutines-core/jvm/src/AbstractTimeSource.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // Need InlineOnly for efficient bytecode on Android @file:Suppress("INVISIBLE_REFERENCE", "INVISIBLE_MEMBER", "NOTHING_TO_INLINE") diff --git a/kotlinx-coroutines-core/jvm/src/Builders.kt b/kotlinx-coroutines-core/jvm/src/Builders.kt index 8c4b62b19d..268194d57a 100644 --- a/kotlinx-coroutines-core/jvm/src/Builders.kt +++ b/kotlinx-coroutines-core/jvm/src/Builders.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("BuildersKt") @file:OptIn(ExperimentalContracts::class) diff --git a/kotlinx-coroutines-core/jvm/src/CoroutineContext.kt b/kotlinx-coroutines-core/jvm/src/CoroutineContext.kt index b736125d35..fe7e22d64e 100644 --- a/kotlinx-coroutines-core/jvm/src/CoroutineContext.kt +++ b/kotlinx-coroutines-core/jvm/src/CoroutineContext.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/jvm/src/Debug.kt b/kotlinx-coroutines-core/jvm/src/Debug.kt index 4e4c9cb2a5..54f085b3a6 100644 --- a/kotlinx-coroutines-core/jvm/src/Debug.kt +++ b/kotlinx-coroutines-core/jvm/src/Debug.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // Need InlineOnly for efficient bytecode on Android @file:Suppress("INVISIBLE_REFERENCE", "INVISIBLE_MEMBER") diff --git a/kotlinx-coroutines-core/jvm/src/DebugStrings.kt b/kotlinx-coroutines-core/jvm/src/DebugStrings.kt index 32bd07a72d..ce5adc5655 100644 --- a/kotlinx-coroutines-core/jvm/src/DebugStrings.kt +++ b/kotlinx-coroutines-core/jvm/src/DebugStrings.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/jvm/src/DefaultExecutor.kt b/kotlinx-coroutines-core/jvm/src/DefaultExecutor.kt index 3229502b32..b467cd180a 100644 --- a/kotlinx-coroutines-core/jvm/src/DefaultExecutor.kt +++ b/kotlinx-coroutines-core/jvm/src/DefaultExecutor.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/jvm/src/Dispatchers.kt b/kotlinx-coroutines-core/jvm/src/Dispatchers.kt index 2222f0dabb..6b3fa5e5e8 100644 --- a/kotlinx-coroutines-core/jvm/src/Dispatchers.kt +++ b/kotlinx-coroutines-core/jvm/src/Dispatchers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/jvm/src/EventLoop.kt b/kotlinx-coroutines-core/jvm/src/EventLoop.kt index 147d62c4f7..614acb1eca 100644 --- a/kotlinx-coroutines-core/jvm/src/EventLoop.kt +++ b/kotlinx-coroutines-core/jvm/src/EventLoop.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.Runnable diff --git a/kotlinx-coroutines-core/jvm/src/Exceptions.kt b/kotlinx-coroutines-core/jvm/src/Exceptions.kt index 410ba8e12f..6175595713 100644 --- a/kotlinx-coroutines-core/jvm/src/Exceptions.kt +++ b/kotlinx-coroutines-core/jvm/src/Exceptions.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("FunctionName") package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/jvm/src/Executors.kt b/kotlinx-coroutines-core/jvm/src/Executors.kt index 121ba3f443..53ef77dcc0 100644 --- a/kotlinx-coroutines-core/jvm/src/Executors.kt +++ b/kotlinx-coroutines-core/jvm/src/Executors.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.flow.* diff --git a/kotlinx-coroutines-core/jvm/src/Future.kt b/kotlinx-coroutines-core/jvm/src/Future.kt index b27a970845..c2425dba73 100644 --- a/kotlinx-coroutines-core/jvm/src/Future.kt +++ b/kotlinx-coroutines-core/jvm/src/Future.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("JobKt") diff --git a/kotlinx-coroutines-core/jvm/src/Interruptible.kt b/kotlinx-coroutines-core/jvm/src/Interruptible.kt index 8129be7bfe..595c5062f7 100644 --- a/kotlinx-coroutines-core/jvm/src/Interruptible.kt +++ b/kotlinx-coroutines-core/jvm/src/Interruptible.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/src/Runnable.kt b/kotlinx-coroutines-core/jvm/src/Runnable.kt index 844f9fcab9..73440eeb8f 100644 --- a/kotlinx-coroutines-core/jvm/src/Runnable.kt +++ b/kotlinx-coroutines-core/jvm/src/Runnable.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines /** diff --git a/kotlinx-coroutines-core/jvm/src/SchedulerTask.kt b/kotlinx-coroutines-core/jvm/src/SchedulerTask.kt index 6a00f45f13..5f81dd33d3 100644 --- a/kotlinx-coroutines-core/jvm/src/SchedulerTask.kt +++ b/kotlinx-coroutines-core/jvm/src/SchedulerTask.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.scheduling.* diff --git a/kotlinx-coroutines-core/jvm/src/ThreadContextElement.kt b/kotlinx-coroutines-core/jvm/src/ThreadContextElement.kt index bfe999589b..15b27802ef 100644 --- a/kotlinx-coroutines-core/jvm/src/ThreadContextElement.kt +++ b/kotlinx-coroutines-core/jvm/src/ThreadContextElement.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/jvm/src/ThreadPoolDispatcher.kt b/kotlinx-coroutines-core/jvm/src/ThreadPoolDispatcher.kt index 50ce20630c..c385b706e7 100644 --- a/kotlinx-coroutines-core/jvm/src/ThreadPoolDispatcher.kt +++ b/kotlinx-coroutines-core/jvm/src/ThreadPoolDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("ThreadPoolDispatcherKt") package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/jvm/src/channels/Actor.kt b/kotlinx-coroutines-core/jvm/src/channels/Actor.kt index 6e2bef6680..62eb19e747 100644 --- a/kotlinx-coroutines-core/jvm/src/channels/Actor.kt +++ b/kotlinx-coroutines-core/jvm/src/channels/Actor.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/src/channels/TickerChannels.kt b/kotlinx-coroutines-core/jvm/src/channels/TickerChannels.kt index 6c23982ee7..c07e68dc4e 100644 --- a/kotlinx-coroutines-core/jvm/src/channels/TickerChannels.kt +++ b/kotlinx-coroutines-core/jvm/src/channels/TickerChannels.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/src/debug/AgentPremain.kt b/kotlinx-coroutines-core/jvm/src/debug/AgentPremain.kt index fb5c5b1b06..4f8abb8700 100644 --- a/kotlinx-coroutines-core/jvm/src/debug/AgentPremain.kt +++ b/kotlinx-coroutines-core/jvm/src/debug/AgentPremain.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug import android.annotation.* diff --git a/kotlinx-coroutines-core/jvm/src/debug/CoroutineDebugging.kt b/kotlinx-coroutines-core/jvm/src/debug/CoroutineDebugging.kt index 49a794e046..7029994276 100644 --- a/kotlinx-coroutines-core/jvm/src/debug/CoroutineDebugging.kt +++ b/kotlinx-coroutines-core/jvm/src/debug/CoroutineDebugging.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - /* This package name is like this so that 1) the artificial stack frames look pretty, and 2) the IDE reliably navigates to this file. */ diff --git a/kotlinx-coroutines-core/jvm/src/debug/internal/AgentInstallationType.kt b/kotlinx-coroutines-core/jvm/src/debug/internal/AgentInstallationType.kt index 0e9b26ce02..15eead7fc3 100644 --- a/kotlinx-coroutines-core/jvm/src/debug/internal/AgentInstallationType.kt +++ b/kotlinx-coroutines-core/jvm/src/debug/internal/AgentInstallationType.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.internal /** diff --git a/kotlinx-coroutines-core/jvm/src/debug/internal/ConcurrentWeakMap.kt b/kotlinx-coroutines-core/jvm/src/debug/internal/ConcurrentWeakMap.kt index b02eac6397..f28d9a6d42 100644 --- a/kotlinx-coroutines-core/jvm/src/debug/internal/ConcurrentWeakMap.kt +++ b/kotlinx-coroutines-core/jvm/src/debug/internal/ConcurrentWeakMap.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/src/debug/internal/DebugCoroutineInfo.kt b/kotlinx-coroutines-core/jvm/src/debug/internal/DebugCoroutineInfo.kt index 56ca6c51b1..91a4cadc59 100644 --- a/kotlinx-coroutines-core/jvm/src/debug/internal/DebugCoroutineInfo.kt +++ b/kotlinx-coroutines-core/jvm/src/debug/internal/DebugCoroutineInfo.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.internal import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/src/debug/internal/DebugCoroutineInfoImpl.kt b/kotlinx-coroutines-core/jvm/src/debug/internal/DebugCoroutineInfoImpl.kt index 261d247ce6..d2d61d3418 100644 --- a/kotlinx-coroutines-core/jvm/src/debug/internal/DebugCoroutineInfoImpl.kt +++ b/kotlinx-coroutines-core/jvm/src/debug/internal/DebugCoroutineInfoImpl.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.internal import java.lang.ref.* diff --git a/kotlinx-coroutines-core/jvm/src/debug/internal/DebugProbes.kt b/kotlinx-coroutines-core/jvm/src/debug/internal/DebugProbes.kt index 8dc5b7c23d..672990e16e 100644 --- a/kotlinx-coroutines-core/jvm/src/debug/internal/DebugProbes.kt +++ b/kotlinx-coroutines-core/jvm/src/debug/internal/DebugProbes.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("unused") package kotlinx.coroutines.debug.internal diff --git a/kotlinx-coroutines-core/jvm/src/debug/internal/DebugProbesImpl.kt b/kotlinx-coroutines-core/jvm/src/debug/internal/DebugProbesImpl.kt index c19d8f2809..22ce410d7b 100644 --- a/kotlinx-coroutines-core/jvm/src/debug/internal/DebugProbesImpl.kt +++ b/kotlinx-coroutines-core/jvm/src/debug/internal/DebugProbesImpl.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/src/debug/internal/DebuggerInfo.kt b/kotlinx-coroutines-core/jvm/src/debug/internal/DebuggerInfo.kt index 0b63cd2308..342c12381e 100644 --- a/kotlinx-coroutines-core/jvm/src/debug/internal/DebuggerInfo.kt +++ b/kotlinx-coroutines-core/jvm/src/debug/internal/DebuggerInfo.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("UNUSED") package kotlinx.coroutines.debug.internal diff --git a/kotlinx-coroutines-core/jvm/src/debug/internal/StackTraceFrame.kt b/kotlinx-coroutines-core/jvm/src/debug/internal/StackTraceFrame.kt index 6cdd5f21ff..d78054592a 100644 --- a/kotlinx-coroutines-core/jvm/src/debug/internal/StackTraceFrame.kt +++ b/kotlinx-coroutines-core/jvm/src/debug/internal/StackTraceFrame.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.internal import kotlin.coroutines.jvm.internal.* diff --git a/kotlinx-coroutines-core/jvm/src/flow/internal/FlowExceptions.kt b/kotlinx-coroutines-core/jvm/src/flow/internal/FlowExceptions.kt index cfe5b69958..5ec064c35b 100644 --- a/kotlinx-coroutines-core/jvm/src/flow/internal/FlowExceptions.kt +++ b/kotlinx-coroutines-core/jvm/src/flow/internal/FlowExceptions.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/src/flow/internal/SafeCollector.kt b/kotlinx-coroutines-core/jvm/src/flow/internal/SafeCollector.kt index 04ffed9717..39fcffa7c5 100644 --- a/kotlinx-coroutines-core/jvm/src/flow/internal/SafeCollector.kt +++ b/kotlinx-coroutines-core/jvm/src/flow/internal/SafeCollector.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/src/internal/Concurrent.kt b/kotlinx-coroutines-core/jvm/src/internal/Concurrent.kt index 5df79b8d75..9ebeed0ad9 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/Concurrent.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/Concurrent.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import java.lang.reflect.* diff --git a/kotlinx-coroutines-core/jvm/src/internal/CoroutineExceptionHandlerImpl.kt b/kotlinx-coroutines-core/jvm/src/internal/CoroutineExceptionHandlerImpl.kt index 7f11898a09..0014e1742f 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/CoroutineExceptionHandlerImpl.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/CoroutineExceptionHandlerImpl.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import java.util.* diff --git a/kotlinx-coroutines-core/jvm/src/internal/ExceptionsConstructor.kt b/kotlinx-coroutines-core/jvm/src/internal/ExceptionsConstructor.kt index 03308f6137..de1225ada5 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/ExceptionsConstructor.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/ExceptionsConstructor.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/src/internal/FastServiceLoader.kt b/kotlinx-coroutines-core/jvm/src/internal/FastServiceLoader.kt index e93de2aad7..6267581f3c 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/FastServiceLoader.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/FastServiceLoader.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import java.io.* diff --git a/kotlinx-coroutines-core/jvm/src/internal/InternalAnnotations.kt b/kotlinx-coroutines-core/jvm/src/internal/InternalAnnotations.kt index 41707f7b89..16b4a48776 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/InternalAnnotations.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/InternalAnnotations.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal @Suppress("ACTUAL_WITHOUT_EXPECT") // Not the same name to WA the bug in the compiler diff --git a/kotlinx-coroutines-core/jvm/src/internal/LocalAtomics.kt b/kotlinx-coroutines-core/jvm/src/internal/LocalAtomics.kt index 9dda30b5d8..febc5b90d9 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/LocalAtomics.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/LocalAtomics.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal @Suppress("ACTUAL_WITHOUT_EXPECT") diff --git a/kotlinx-coroutines-core/jvm/src/internal/MainDispatchers.kt b/kotlinx-coroutines-core/jvm/src/internal/MainDispatchers.kt index 0c55d92eb8..3eaf723e9a 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/MainDispatchers.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/MainDispatchers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/src/internal/ProbesSupport.kt b/kotlinx-coroutines-core/jvm/src/internal/ProbesSupport.kt index 48e01fbeff..53713be320 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/ProbesSupport.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/ProbesSupport.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("NOTHING_TO_INLINE", "INVISIBLE_REFERENCE", "INVISIBLE_MEMBER") package kotlinx.coroutines.internal diff --git a/kotlinx-coroutines-core/jvm/src/internal/ResizableAtomicArray.kt b/kotlinx-coroutines-core/jvm/src/internal/ResizableAtomicArray.kt index 6c98a9dad9..9cc2983ffe 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/ResizableAtomicArray.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/ResizableAtomicArray.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import java.util.concurrent.atomic.* diff --git a/kotlinx-coroutines-core/jvm/src/internal/StackTraceRecovery.kt b/kotlinx-coroutines-core/jvm/src/internal/StackTraceRecovery.kt index d1833492ae..619c61a1fa 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/StackTraceRecovery.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/StackTraceRecovery.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("UNCHECKED_CAST") package kotlinx.coroutines.internal diff --git a/kotlinx-coroutines-core/jvm/src/internal/Synchronized.kt b/kotlinx-coroutines-core/jvm/src/internal/Synchronized.kt index 5b12faaf09..47273d6ceb 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/Synchronized.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/Synchronized.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/src/internal/SystemProps.kt b/kotlinx-coroutines-core/jvm/src/internal/SystemProps.kt index 73853720ae..837c2ff9ea 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/SystemProps.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/SystemProps.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmName("SystemPropsKt") @file:JvmMultifileClass diff --git a/kotlinx-coroutines-core/jvm/src/internal/ThreadContext.kt b/kotlinx-coroutines-core/jvm/src/internal/ThreadContext.kt index 8536cef65d..8f21b13c25 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/ThreadContext.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/ThreadContext.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/src/internal/ThreadLocal.kt b/kotlinx-coroutines-core/jvm/src/internal/ThreadLocal.kt index 0924a5b396..d5f715621f 100644 --- a/kotlinx-coroutines-core/jvm/src/internal/ThreadLocal.kt +++ b/kotlinx-coroutines-core/jvm/src/internal/ThreadLocal.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import java.lang.ThreadLocal diff --git a/kotlinx-coroutines-core/jvm/src/scheduling/CoroutineScheduler.kt b/kotlinx-coroutines-core/jvm/src/scheduling/CoroutineScheduler.kt index bb195307e9..cfc3a45913 100644 --- a/kotlinx-coroutines-core/jvm/src/scheduling/CoroutineScheduler.kt +++ b/kotlinx-coroutines-core/jvm/src/scheduling/CoroutineScheduler.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/src/scheduling/Deprecated.kt b/kotlinx-coroutines-core/jvm/src/scheduling/Deprecated.kt index e5defbafcd..2fd3173543 100644 --- a/kotlinx-coroutines-core/jvm/src/scheduling/Deprecated.kt +++ b/kotlinx-coroutines-core/jvm/src/scheduling/Deprecated.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("unused") package kotlinx.coroutines.scheduling diff --git a/kotlinx-coroutines-core/jvm/src/scheduling/Dispatcher.kt b/kotlinx-coroutines-core/jvm/src/scheduling/Dispatcher.kt index f91125a27c..f3d66cdef9 100644 --- a/kotlinx-coroutines-core/jvm/src/scheduling/Dispatcher.kt +++ b/kotlinx-coroutines-core/jvm/src/scheduling/Dispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/src/scheduling/Tasks.kt b/kotlinx-coroutines-core/jvm/src/scheduling/Tasks.kt index 5249edf7e0..eefccd514a 100644 --- a/kotlinx-coroutines-core/jvm/src/scheduling/Tasks.kt +++ b/kotlinx-coroutines-core/jvm/src/scheduling/Tasks.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/src/scheduling/WorkQueue.kt b/kotlinx-coroutines-core/jvm/src/scheduling/WorkQueue.kt index a185410ab2..6c8b5616a0 100644 --- a/kotlinx-coroutines-core/jvm/src/scheduling/WorkQueue.kt +++ b/kotlinx-coroutines-core/jvm/src/scheduling/WorkQueue.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/AbstractLincheckTest.kt b/kotlinx-coroutines-core/jvm/test/AbstractLincheckTest.kt index da73ca6220..869b95439c 100644 --- a/kotlinx-coroutines-core/jvm/test/AbstractLincheckTest.kt +++ b/kotlinx-coroutines-core/jvm/test/AbstractLincheckTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines import org.jetbrains.kotlinx.lincheck.* diff --git a/kotlinx-coroutines-core/jvm/test/AsyncJvmTest.kt b/kotlinx-coroutines-core/jvm/test/AsyncJvmTest.kt index 59ff76a538..e50eff1ec3 100644 --- a/kotlinx-coroutines-core/jvm/test/AsyncJvmTest.kt +++ b/kotlinx-coroutines-core/jvm/test/AsyncJvmTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/jvm/test/AwaitJvmTest.kt b/kotlinx-coroutines-core/jvm/test/AwaitJvmTest.kt index c6b57c8f6b..f6fe8e13b8 100644 --- a/kotlinx-coroutines-core/jvm/test/AwaitJvmTest.kt +++ b/kotlinx-coroutines-core/jvm/test/AwaitJvmTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/AwaitStressTest.kt b/kotlinx-coroutines-core/jvm/test/AwaitStressTest.kt index 6b711db5a6..5f6c6edd43 100644 --- a/kotlinx-coroutines-core/jvm/test/AwaitStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/AwaitStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/CancellableContinuationJvmTest.kt b/kotlinx-coroutines-core/jvm/test/CancellableContinuationJvmTest.kt index f1a957adca..cca06d0368 100644 --- a/kotlinx-coroutines-core/jvm/test/CancellableContinuationJvmTest.kt +++ b/kotlinx-coroutines-core/jvm/test/CancellableContinuationJvmTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/CancellableContinuationResumeCloseStressTest.kt b/kotlinx-coroutines-core/jvm/test/CancellableContinuationResumeCloseStressTest.kt index b8bc3f00be..d9ce0266da 100644 --- a/kotlinx-coroutines-core/jvm/test/CancellableContinuationResumeCloseStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/CancellableContinuationResumeCloseStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/CancelledAwaitStressTest.kt b/kotlinx-coroutines-core/jvm/test/CancelledAwaitStressTest.kt index c7c2c04e59..7d82a5e650 100644 --- a/kotlinx-coroutines-core/jvm/test/CancelledAwaitStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/CancelledAwaitStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/ConcurrentTestUtilities.kt b/kotlinx-coroutines-core/jvm/test/ConcurrentTestUtilities.kt index d9acccdf86..6d6bc2127f 100644 --- a/kotlinx-coroutines-core/jvm/test/ConcurrentTestUtilities.kt +++ b/kotlinx-coroutines-core/jvm/test/ConcurrentTestUtilities.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions actual inline fun yieldThread() { Thread.yield() } diff --git a/kotlinx-coroutines-core/jvm/test/CoroutinesJvmTest.kt b/kotlinx-coroutines-core/jvm/test/CoroutinesJvmTest.kt index e890ea2146..c23b4f35ea 100644 --- a/kotlinx-coroutines-core/jvm/test/CoroutinesJvmTest.kt +++ b/kotlinx-coroutines-core/jvm/test/CoroutinesJvmTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/jvm/test/DebugThreadNameTest.kt b/kotlinx-coroutines-core/jvm/test/DebugThreadNameTest.kt index 9d683960f0..5e88e34ce7 100644 --- a/kotlinx-coroutines-core/jvm/test/DebugThreadNameTest.kt +++ b/kotlinx-coroutines-core/jvm/test/DebugThreadNameTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/jvm/test/DefaultExecutorStressTest.kt b/kotlinx-coroutines-core/jvm/test/DefaultExecutorStressTest.kt index bc2de8c998..26dad4e6c6 100644 --- a/kotlinx-coroutines-core/jvm/test/DefaultExecutorStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/DefaultExecutorStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/DelayJvmTest.kt b/kotlinx-coroutines-core/jvm/test/DelayJvmTest.kt index 2906c316ef..1ed491b790 100644 --- a/kotlinx-coroutines-core/jvm/test/DelayJvmTest.kt +++ b/kotlinx-coroutines-core/jvm/test/DelayJvmTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/DispatcherKeyTest.kt b/kotlinx-coroutines-core/jvm/test/DispatcherKeyTest.kt index 303e8cc8fe..673097dbf5 100644 --- a/kotlinx-coroutines-core/jvm/test/DispatcherKeyTest.kt +++ b/kotlinx-coroutines-core/jvm/test/DispatcherKeyTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/DispatchersToStringTest.kt b/kotlinx-coroutines-core/jvm/test/DispatchersToStringTest.kt index 7adaa2a4b6..9bd7e8c1e6 100644 --- a/kotlinx-coroutines-core/jvm/test/DispatchersToStringTest.kt +++ b/kotlinx-coroutines-core/jvm/test/DispatchersToStringTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/jvm/test/EventLoopsTest.kt b/kotlinx-coroutines-core/jvm/test/EventLoopsTest.kt index 835e6b427c..0e7ef93a46 100644 --- a/kotlinx-coroutines-core/jvm/test/EventLoopsTest.kt +++ b/kotlinx-coroutines-core/jvm/test/EventLoopsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/ExecutorAsCoroutineDispatcherDelayTest.kt b/kotlinx-coroutines-core/jvm/test/ExecutorAsCoroutineDispatcherDelayTest.kt index dbe9cb3741..982493f576 100644 --- a/kotlinx-coroutines-core/jvm/test/ExecutorAsCoroutineDispatcherDelayTest.kt +++ b/kotlinx-coroutines-core/jvm/test/ExecutorAsCoroutineDispatcherDelayTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/ExecutorRule.kt b/kotlinx-coroutines-core/jvm/test/ExecutorRule.kt index e9cf6bcfc3..a90621df7d 100644 --- a/kotlinx-coroutines-core/jvm/test/ExecutorRule.kt +++ b/kotlinx-coroutines-core/jvm/test/ExecutorRule.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.rules.* diff --git a/kotlinx-coroutines-core/jvm/test/ExecutorsTest.kt b/kotlinx-coroutines-core/jvm/test/ExecutorsTest.kt index 6e5b18f7e9..892ed55841 100644 --- a/kotlinx-coroutines-core/jvm/test/ExecutorsTest.kt +++ b/kotlinx-coroutines-core/jvm/test/ExecutorsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/FailFastOnStartTest.kt b/kotlinx-coroutines-core/jvm/test/FailFastOnStartTest.kt index 8a7878c9a6..8446fccfe9 100644 --- a/kotlinx-coroutines-core/jvm/test/FailFastOnStartTest.kt +++ b/kotlinx-coroutines-core/jvm/test/FailFastOnStartTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("DeferredResultUnused") package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/jvm/test/FailingCoroutinesMachineryTest.kt b/kotlinx-coroutines-core/jvm/test/FailingCoroutinesMachineryTest.kt index 04b0ba547d..0125a71d55 100644 --- a/kotlinx-coroutines-core/jvm/test/FailingCoroutinesMachineryTest.kt +++ b/kotlinx-coroutines-core/jvm/test/FailingCoroutinesMachineryTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/FieldWalker.kt b/kotlinx-coroutines-core/jvm/test/FieldWalker.kt index 53fe97d53f..8566494534 100644 --- a/kotlinx-coroutines-core/jvm/test/FieldWalker.kt +++ b/kotlinx-coroutines-core/jvm/test/FieldWalker.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import java.lang.ref.* diff --git a/kotlinx-coroutines-core/jvm/test/IODispatcherTest.kt b/kotlinx-coroutines-core/jvm/test/IODispatcherTest.kt index fe3c71a804..b3f3754f58 100644 --- a/kotlinx-coroutines-core/jvm/test/IODispatcherTest.kt +++ b/kotlinx-coroutines-core/jvm/test/IODispatcherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/IntellijIdeaDebuggerEvaluatorCompatibilityTest.kt b/kotlinx-coroutines-core/jvm/test/IntellijIdeaDebuggerEvaluatorCompatibilityTest.kt index 6bbfdd1b4b..56f2f3b809 100644 --- a/kotlinx-coroutines-core/jvm/test/IntellijIdeaDebuggerEvaluatorCompatibilityTest.kt +++ b/kotlinx-coroutines-core/jvm/test/IntellijIdeaDebuggerEvaluatorCompatibilityTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/JobActivationStressTest.kt b/kotlinx-coroutines-core/jvm/test/JobActivationStressTest.kt index 8341df920c..8b9592b731 100644 --- a/kotlinx-coroutines-core/jvm/test/JobActivationStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/JobActivationStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/JobCancellationExceptionSerializerTest.kt b/kotlinx-coroutines-core/jvm/test/JobCancellationExceptionSerializerTest.kt index c909f27b64..cff3fbf1a5 100644 --- a/kotlinx-coroutines-core/jvm/test/JobCancellationExceptionSerializerTest.kt +++ b/kotlinx-coroutines-core/jvm/test/JobCancellationExceptionSerializerTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/JobChildStressTest.kt b/kotlinx-coroutines-core/jvm/test/JobChildStressTest.kt index 107cc52cb5..46b3928ec9 100644 --- a/kotlinx-coroutines-core/jvm/test/JobChildStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/JobChildStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/JobDisposeStressTest.kt b/kotlinx-coroutines-core/jvm/test/JobDisposeStressTest.kt index 3a074f1568..f3b5b4974b 100644 --- a/kotlinx-coroutines-core/jvm/test/JobDisposeStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/JobDisposeStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/JobHandlersUpgradeStressTest.kt b/kotlinx-coroutines-core/jvm/test/JobHandlersUpgradeStressTest.kt index 0a03247d34..f9c9979357 100644 --- a/kotlinx-coroutines-core/jvm/test/JobHandlersUpgradeStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/JobHandlersUpgradeStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/JobStressTest.kt b/kotlinx-coroutines-core/jvm/test/JobStressTest.kt index 2decb3d8b1..fab7a3a3fb 100644 --- a/kotlinx-coroutines-core/jvm/test/JobStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/JobStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/jvm/test/JoinStressTest.kt b/kotlinx-coroutines-core/jvm/test/JoinStressTest.kt index 6d47418564..e0e0de8b20 100644 --- a/kotlinx-coroutines-core/jvm/test/JoinStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/JoinStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/LimitedParallelismStressTest.kt b/kotlinx-coroutines-core/jvm/test/LimitedParallelismStressTest.kt index 58f2b6b35a..9a79780755 100644 --- a/kotlinx-coroutines-core/jvm/test/LimitedParallelismStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/LimitedParallelismStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/LimitedParallelismUnhandledExceptionTest.kt b/kotlinx-coroutines-core/jvm/test/LimitedParallelismUnhandledExceptionTest.kt index 8d48aa43b3..0ce9b2279a 100644 --- a/kotlinx-coroutines-core/jvm/test/LimitedParallelismUnhandledExceptionTest.kt +++ b/kotlinx-coroutines-core/jvm/test/LimitedParallelismUnhandledExceptionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/MemoryFootprintTest.kt b/kotlinx-coroutines-core/jvm/test/MemoryFootprintTest.kt index be467cc5cd..fd8c7504d9 100644 --- a/kotlinx-coroutines-core/jvm/test/MemoryFootprintTest.kt +++ b/kotlinx-coroutines-core/jvm/test/MemoryFootprintTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/MutexCancellationStressTest.kt b/kotlinx-coroutines-core/jvm/test/MutexCancellationStressTest.kt index 20798b837d..d5627bc985 100644 --- a/kotlinx-coroutines-core/jvm/test/MutexCancellationStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/MutexCancellationStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/jvm/test/NoParamAssertionsTest.kt b/kotlinx-coroutines-core/jvm/test/NoParamAssertionsTest.kt index 5e1c4625e7..729e8acbcf 100644 --- a/kotlinx-coroutines-core/jvm/test/NoParamAssertionsTest.kt +++ b/kotlinx-coroutines-core/jvm/test/NoParamAssertionsTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/RejectedExecutionTest.kt b/kotlinx-coroutines-core/jvm/test/RejectedExecutionTest.kt index 7f6d6b661c..1547151230 100644 --- a/kotlinx-coroutines-core/jvm/test/RejectedExecutionTest.kt +++ b/kotlinx-coroutines-core/jvm/test/RejectedExecutionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.flow.* diff --git a/kotlinx-coroutines-core/jvm/test/ReusableCancellableContinuationInvariantStressTest.kt b/kotlinx-coroutines-core/jvm/test/ReusableCancellableContinuationInvariantStressTest.kt index 4d8116c982..9e6107800d 100644 --- a/kotlinx-coroutines-core/jvm/test/ReusableCancellableContinuationInvariantStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/ReusableCancellableContinuationInvariantStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/ReusableCancellableContinuationLeakStressTest.kt b/kotlinx-coroutines-core/jvm/test/ReusableCancellableContinuationLeakStressTest.kt index 8a20e0843f..e5059432f9 100644 --- a/kotlinx-coroutines-core/jvm/test/ReusableCancellableContinuationLeakStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/ReusableCancellableContinuationLeakStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.channels.* diff --git a/kotlinx-coroutines-core/jvm/test/ReusableCancellableContinuationTest.kt b/kotlinx-coroutines-core/jvm/test/ReusableCancellableContinuationTest.kt index 06839f4a04..c3944c6d46 100644 --- a/kotlinx-coroutines-core/jvm/test/ReusableCancellableContinuationTest.kt +++ b/kotlinx-coroutines-core/jvm/test/ReusableCancellableContinuationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.channels.* diff --git a/kotlinx-coroutines-core/jvm/test/ReusableContinuationStressTest.kt b/kotlinx-coroutines-core/jvm/test/ReusableContinuationStressTest.kt index a256815db3..ccff46dbc5 100644 --- a/kotlinx-coroutines-core/jvm/test/ReusableContinuationStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/ReusableContinuationStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.flow.* diff --git a/kotlinx-coroutines-core/jvm/test/RunBlockingJvmTest.kt b/kotlinx-coroutines-core/jvm/test/RunBlockingJvmTest.kt index 057a8bbc96..bc60a3aa08 100644 --- a/kotlinx-coroutines-core/jvm/test/RunBlockingJvmTest.kt +++ b/kotlinx-coroutines-core/jvm/test/RunBlockingJvmTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/RunInterruptibleStressTest.kt b/kotlinx-coroutines-core/jvm/test/RunInterruptibleStressTest.kt index 701b958afd..c846197461 100644 --- a/kotlinx-coroutines-core/jvm/test/RunInterruptibleStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/RunInterruptibleStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/RunInterruptibleTest.kt b/kotlinx-coroutines-core/jvm/test/RunInterruptibleTest.kt index 49c93c7fe2..3208d041a1 100644 --- a/kotlinx-coroutines-core/jvm/test/RunInterruptibleTest.kt +++ b/kotlinx-coroutines-core/jvm/test/RunInterruptibleTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.channels.* diff --git a/kotlinx-coroutines-core/jvm/test/TestBase.kt b/kotlinx-coroutines-core/jvm/test/TestBase.kt index 48c01d8342..f49eb31d48 100644 --- a/kotlinx-coroutines-core/jvm/test/TestBase.kt +++ b/kotlinx-coroutines-core/jvm/test/TestBase.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/jvm/test/TestBaseTest.kt b/kotlinx-coroutines-core/jvm/test/TestBaseTest.kt index b198102767..2c66b0c4c3 100644 --- a/kotlinx-coroutines-core/jvm/test/TestBaseTest.kt +++ b/kotlinx-coroutines-core/jvm/test/TestBaseTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/TestSecurityManager.kt b/kotlinx-coroutines-core/jvm/test/TestSecurityManager.kt index e7b039ce3b..781d5d070b 100644 --- a/kotlinx-coroutines-core/jvm/test/TestSecurityManager.kt +++ b/kotlinx-coroutines-core/jvm/test/TestSecurityManager.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import java.security.Permission diff --git a/kotlinx-coroutines-core/jvm/test/ThreadContextElementRestoreTest.kt b/kotlinx-coroutines-core/jvm/test/ThreadContextElementRestoreTest.kt index e2ab4d7282..5cdaa9c533 100644 --- a/kotlinx-coroutines-core/jvm/test/ThreadContextElementRestoreTest.kt +++ b/kotlinx-coroutines-core/jvm/test/ThreadContextElementRestoreTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/ThreadContextElementTest.kt b/kotlinx-coroutines-core/jvm/test/ThreadContextElementTest.kt index 3bb79b4971..4255cf7eaa 100644 --- a/kotlinx-coroutines-core/jvm/test/ThreadContextElementTest.kt +++ b/kotlinx-coroutines-core/jvm/test/ThreadContextElementTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/ThreadContextMutableCopiesTest.kt b/kotlinx-coroutines-core/jvm/test/ThreadContextMutableCopiesTest.kt index 73d4ee6e9e..6aa033bac9 100644 --- a/kotlinx-coroutines-core/jvm/test/ThreadContextMutableCopiesTest.kt +++ b/kotlinx-coroutines-core/jvm/test/ThreadContextMutableCopiesTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.flow.* diff --git a/kotlinx-coroutines-core/jvm/test/ThreadContextOrderTest.kt b/kotlinx-coroutines-core/jvm/test/ThreadContextOrderTest.kt index 49f4a12ee0..53f233786c 100644 --- a/kotlinx-coroutines-core/jvm/test/ThreadContextOrderTest.kt +++ b/kotlinx-coroutines-core/jvm/test/ThreadContextOrderTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/jvm/test/ThreadLocalStressTest.kt b/kotlinx-coroutines-core/jvm/test/ThreadLocalStressTest.kt index 20621d12bf..94d72ba742 100644 --- a/kotlinx-coroutines-core/jvm/test/ThreadLocalStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/ThreadLocalStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.sync.* diff --git a/kotlinx-coroutines-core/jvm/test/ThreadLocalTest.kt b/kotlinx-coroutines-core/jvm/test/ThreadLocalTest.kt index 5d8c3d5c6d..be001aa489 100644 --- a/kotlinx-coroutines-core/jvm/test/ThreadLocalTest.kt +++ b/kotlinx-coroutines-core/jvm/test/ThreadLocalTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/Threads.kt b/kotlinx-coroutines-core/jvm/test/Threads.kt index 1d52dc6b60..a2c2450064 100644 --- a/kotlinx-coroutines-core/jvm/test/Threads.kt +++ b/kotlinx-coroutines-core/jvm/test/Threads.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines private const val WAIT_LOST_THREADS = 10_000L // 10s diff --git a/kotlinx-coroutines-core/jvm/test/UnconfinedConcurrentStressTest.kt b/kotlinx-coroutines-core/jvm/test/UnconfinedConcurrentStressTest.kt index 03088006f1..226a782e69 100644 --- a/kotlinx-coroutines-core/jvm/test/UnconfinedConcurrentStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/UnconfinedConcurrentStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.* diff --git a/kotlinx-coroutines-core/jvm/test/VirtualTimeSource.kt b/kotlinx-coroutines-core/jvm/test/VirtualTimeSource.kt index b4bc96ebdd..097e7eeef4 100644 --- a/kotlinx-coroutines-core/jvm/test/VirtualTimeSource.kt +++ b/kotlinx-coroutines-core/jvm/test/VirtualTimeSource.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import java.io.* diff --git a/kotlinx-coroutines-core/jvm/test/WithDefaultContextTest.kt b/kotlinx-coroutines-core/jvm/test/WithDefaultContextTest.kt index 0cad285310..78762f94c8 100644 --- a/kotlinx-coroutines-core/jvm/test/WithDefaultContextTest.kt +++ b/kotlinx-coroutines-core/jvm/test/WithDefaultContextTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/jvm/test/WithTimeoutChildDipspatchStressTest.kt b/kotlinx-coroutines-core/jvm/test/WithTimeoutChildDipspatchStressTest.kt index 4d440a7cae..49a92a602a 100644 --- a/kotlinx-coroutines-core/jvm/test/WithTimeoutChildDipspatchStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/WithTimeoutChildDipspatchStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.junit.Test diff --git a/kotlinx-coroutines-core/jvm/test/WithTimeoutOrNullJvmTest.kt b/kotlinx-coroutines-core/jvm/test/WithTimeoutOrNullJvmTest.kt index cce77bb617..4537c8d536 100644 --- a/kotlinx-coroutines-core/jvm/test/WithTimeoutOrNullJvmTest.kt +++ b/kotlinx-coroutines-core/jvm/test/WithTimeoutOrNullJvmTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/jvm/test/WithTimeoutOrNullThreadDispatchTest.kt b/kotlinx-coroutines-core/jvm/test/WithTimeoutOrNullThreadDispatchTest.kt index ea1ba1a9bb..3ca6f4d3d0 100644 --- a/kotlinx-coroutines-core/jvm/test/WithTimeoutOrNullThreadDispatchTest.kt +++ b/kotlinx-coroutines-core/jvm/test/WithTimeoutOrNullThreadDispatchTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/jvm/test/WithTimeoutThreadDispatchTest.kt b/kotlinx-coroutines-core/jvm/test/WithTimeoutThreadDispatchTest.kt index 82f5e92d62..848bc2a4b6 100644 --- a/kotlinx-coroutines-core/jvm/test/WithTimeoutThreadDispatchTest.kt +++ b/kotlinx-coroutines-core/jvm/test/WithTimeoutThreadDispatchTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.test.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/ActorLazyTest.kt b/kotlinx-coroutines-core/jvm/test/channels/ActorLazyTest.kt index d3b2ff1265..bfdc2b4045 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/ActorLazyTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/ActorLazyTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/ActorTest.kt b/kotlinx-coroutines-core/jvm/test/channels/ActorTest.kt index 5a2778d507..1f9790a7b7 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/ActorTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/ActorTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/BroadcastChannelMultiReceiveStressTest.kt b/kotlinx-coroutines-core/jvm/test/channels/BroadcastChannelMultiReceiveStressTest.kt index 8c9777b4af..2777bfb42a 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/BroadcastChannelMultiReceiveStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/BroadcastChannelMultiReceiveStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/BufferedChannelStressTest.kt b/kotlinx-coroutines-core/jvm/test/channels/BufferedChannelStressTest.kt index a6464263cc..0dc6c70729 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/BufferedChannelStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/BufferedChannelStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/ChannelMemoryLeakStressTest.kt b/kotlinx-coroutines-core/jvm/test/channels/ChannelMemoryLeakStressTest.kt index ebc2bee89a..db96f61e03 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/ChannelMemoryLeakStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/ChannelMemoryLeakStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/ChannelSelectStressTest.kt b/kotlinx-coroutines-core/jvm/test/channels/ChannelSelectStressTest.kt index a44ff6cdc6..45ccddcf52 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/ChannelSelectStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/ChannelSelectStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/ChannelSendReceiveStressTest.kt b/kotlinx-coroutines-core/jvm/test/channels/ChannelSendReceiveStressTest.kt index 8a60ce5051..230041a2f6 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/ChannelSendReceiveStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/ChannelSendReceiveStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/ChannelUndeliveredElementSelectOldStressTest.kt b/kotlinx-coroutines-core/jvm/test/channels/ChannelUndeliveredElementSelectOldStressTest.kt index 25cccf948a..7e2c08e503 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/ChannelUndeliveredElementSelectOldStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/ChannelUndeliveredElementSelectOldStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/ChannelUndeliveredElementStressTest.kt b/kotlinx-coroutines-core/jvm/test/channels/ChannelUndeliveredElementStressTest.kt index f8a5644769..9b44d83603 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/ChannelUndeliveredElementStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/ChannelUndeliveredElementStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/ConflatedChannelCloseStressTest.kt b/kotlinx-coroutines-core/jvm/test/channels/ConflatedChannelCloseStressTest.kt index 793d7e44f5..9c7095a95f 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/ConflatedChannelCloseStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/ConflatedChannelCloseStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/DoubleChannelCloseStressTest.kt b/kotlinx-coroutines-core/jvm/test/channels/DoubleChannelCloseStressTest.kt index 01cace720c..209171516b 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/DoubleChannelCloseStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/DoubleChannelCloseStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/InvokeOnCloseStressTest.kt b/kotlinx-coroutines-core/jvm/test/channels/InvokeOnCloseStressTest.kt index 8ac859137e..7a3974b565 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/InvokeOnCloseStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/InvokeOnCloseStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/ProduceConsumeJvmTest.kt b/kotlinx-coroutines-core/jvm/test/channels/ProduceConsumeJvmTest.kt index 61c6635e8a..1fe45a006c 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/ProduceConsumeJvmTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/ProduceConsumeJvmTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/SendReceiveJvmStressTest.kt b/kotlinx-coroutines-core/jvm/test/channels/SendReceiveJvmStressTest.kt index 60d1adba48..525afca42d 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/SendReceiveJvmStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/SendReceiveJvmStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/SimpleSendReceiveJvmTest.kt b/kotlinx-coroutines-core/jvm/test/channels/SimpleSendReceiveJvmTest.kt index eeddfb5f49..5b40749675 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/SimpleSendReceiveJvmTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/SimpleSendReceiveJvmTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/TickerChannelCommonTest.kt b/kotlinx-coroutines-core/jvm/test/channels/TickerChannelCommonTest.kt index fbc28a1855..e01823324e 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/TickerChannelCommonTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/TickerChannelCommonTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/channels/TickerChannelTest.kt b/kotlinx-coroutines-core/jvm/test/channels/TickerChannelTest.kt index fcdc6bb4ad..b4afc9a547 100644 --- a/kotlinx-coroutines-core/jvm/test/channels/TickerChannelTest.kt +++ b/kotlinx-coroutines-core/jvm/test/channels/TickerChannelTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/examples/example-delay-01.kt b/kotlinx-coroutines-core/jvm/test/examples/example-delay-01.kt index 1bc3791cb5..63dcc081a0 100644 --- a/kotlinx-coroutines-core/jvm/test/examples/example-delay-01.kt +++ b/kotlinx-coroutines-core/jvm/test/examples/example-delay-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from Delay.kt by Knit tool. Do not edit. package kotlinx.coroutines.examples.exampleDelay01 diff --git a/kotlinx-coroutines-core/jvm/test/examples/example-delay-02.kt b/kotlinx-coroutines-core/jvm/test/examples/example-delay-02.kt index ac48af9ad5..498ce33072 100644 --- a/kotlinx-coroutines-core/jvm/test/examples/example-delay-02.kt +++ b/kotlinx-coroutines-core/jvm/test/examples/example-delay-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from Delay.kt by Knit tool. Do not edit. package kotlinx.coroutines.examples.exampleDelay02 diff --git a/kotlinx-coroutines-core/jvm/test/examples/example-delay-03.kt b/kotlinx-coroutines-core/jvm/test/examples/example-delay-03.kt index 1fa9dc46be..f9c44c3d89 100644 --- a/kotlinx-coroutines-core/jvm/test/examples/example-delay-03.kt +++ b/kotlinx-coroutines-core/jvm/test/examples/example-delay-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from Delay.kt by Knit tool. Do not edit. package kotlinx.coroutines.examples.exampleDelay03 diff --git a/kotlinx-coroutines-core/jvm/test/examples/example-delay-duration-01.kt b/kotlinx-coroutines-core/jvm/test/examples/example-delay-duration-01.kt index 954af0662b..00c613fd1c 100644 --- a/kotlinx-coroutines-core/jvm/test/examples/example-delay-duration-01.kt +++ b/kotlinx-coroutines-core/jvm/test/examples/example-delay-duration-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from Delay.kt by Knit tool. Do not edit. package kotlinx.coroutines.examples.exampleDelayDuration01 diff --git a/kotlinx-coroutines-core/jvm/test/examples/example-delay-duration-02.kt b/kotlinx-coroutines-core/jvm/test/examples/example-delay-duration-02.kt index 45935a0982..a75f251706 100644 --- a/kotlinx-coroutines-core/jvm/test/examples/example-delay-duration-02.kt +++ b/kotlinx-coroutines-core/jvm/test/examples/example-delay-duration-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from Delay.kt by Knit tool. Do not edit. package kotlinx.coroutines.examples.exampleDelayDuration02 diff --git a/kotlinx-coroutines-core/jvm/test/examples/example-delay-duration-03.kt b/kotlinx-coroutines-core/jvm/test/examples/example-delay-duration-03.kt index fc389c2474..dbd4842a0a 100644 --- a/kotlinx-coroutines-core/jvm/test/examples/example-delay-duration-03.kt +++ b/kotlinx-coroutines-core/jvm/test/examples/example-delay-duration-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from Delay.kt by Knit tool. Do not edit. package kotlinx.coroutines.examples.exampleDelayDuration03 diff --git a/kotlinx-coroutines-core/jvm/test/examples/example-timeout-duration-01.kt b/kotlinx-coroutines-core/jvm/test/examples/example-timeout-duration-01.kt index 5adda863cb..c336528c8b 100644 --- a/kotlinx-coroutines-core/jvm/test/examples/example-timeout-duration-01.kt +++ b/kotlinx-coroutines-core/jvm/test/examples/example-timeout-duration-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from Delay.kt by Knit tool. Do not edit. package kotlinx.coroutines.examples.exampleTimeoutDuration01 diff --git a/kotlinx-coroutines-core/jvm/test/examples/test/FlowDelayTest.kt b/kotlinx-coroutines-core/jvm/test/examples/test/FlowDelayTest.kt index f7e93b34d9..b0bc05fc8b 100644 --- a/kotlinx-coroutines-core/jvm/test/examples/test/FlowDelayTest.kt +++ b/kotlinx-coroutines-core/jvm/test/examples/test/FlowDelayTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from Delay.kt by Knit tool. Do not edit. package kotlinx.coroutines.examples.test diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/CoroutineExceptionHandlerJvmTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/CoroutineExceptionHandlerJvmTest.kt index 2095f14886..846df5b866 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/CoroutineExceptionHandlerJvmTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/CoroutineExceptionHandlerJvmTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/Exceptions.kt b/kotlinx-coroutines-core/jvm/test/exceptions/Exceptions.kt index e05a892a08..b0dd853c5a 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/Exceptions.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/Exceptions.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/FlowSuppressionTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/FlowSuppressionTest.kt index 41fe090382..0979249272 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/FlowSuppressionTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/FlowSuppressionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/JobBasicCancellationTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/JobBasicCancellationTest.kt index 28d85fe341..e21ef3ea49 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/JobBasicCancellationTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/JobBasicCancellationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/JobExceptionHandlingTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/JobExceptionHandlingTest.kt index eaa73bdb50..85dcac2428 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/JobExceptionHandlingTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/JobExceptionHandlingTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/JobExceptionsStressTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/JobExceptionsStressTest.kt index 4c977e85c5..feb29b8b64 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/JobExceptionsStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/JobExceptionsStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/JobNestedExceptionsTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/JobNestedExceptionsTest.kt index 4a5fa74639..63f85fd3f9 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/JobNestedExceptionsTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/JobNestedExceptionsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/ProduceExceptionsTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/ProduceExceptionsTest.kt index 33585f443d..8e737dc2a8 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/ProduceExceptionsTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/ProduceExceptionsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryChannelsTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryChannelsTest.kt index 2d8c0ebc75..9badd48d08 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryChannelsTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryChannelsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryCustomExceptionsTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryCustomExceptionsTest.kt index 0f987e56e0..65f950be27 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryCustomExceptionsTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryCustomExceptionsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryNestedTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryNestedTest.kt index 02607c0308..7421321af2 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryNestedTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryNestedTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("DeferredResultUnused") package kotlinx.coroutines.exceptions diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryResumeModeTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryResumeModeTest.kt index 36f60523c5..45005aa724 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryResumeModeTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryResumeModeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoverySelectTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoverySelectTest.kt index 0efa252e18..fb6cb626ef 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoverySelectTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoverySelectTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryTest.kt index 1db7c1dbfc..6e0afa7230 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryWithTimeoutTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryWithTimeoutTest.kt index 8e628dbe90..2099e21a92 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryWithTimeoutTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/StackTraceRecoveryWithTimeoutTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/SuppressionTests.kt b/kotlinx-coroutines-core/jvm/test/exceptions/SuppressionTests.kt index edce175d4a..fbcf168dcf 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/SuppressionTests.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/SuppressionTests.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/WithContextCancellationStressTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/WithContextCancellationStressTest.kt index f148a3ae43..864904e021 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/WithContextCancellationStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/WithContextCancellationStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/exceptions/WithContextExceptionHandlingTest.kt b/kotlinx-coroutines-core/jvm/test/exceptions/WithContextExceptionHandlingTest.kt index a95a3da379..8618f9eb6c 100644 --- a/kotlinx-coroutines-core/jvm/test/exceptions/WithContextExceptionHandlingTest.kt +++ b/kotlinx-coroutines-core/jvm/test/exceptions/WithContextExceptionHandlingTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/flow/CallbackFlowTest.kt b/kotlinx-coroutines-core/jvm/test/flow/CallbackFlowTest.kt index f1be284cae..17fa532157 100644 --- a/kotlinx-coroutines-core/jvm/test/flow/CallbackFlowTest.kt +++ b/kotlinx-coroutines-core/jvm/test/flow/CallbackFlowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/flow/ExceptionTransparencyTest.kt b/kotlinx-coroutines-core/jvm/test/flow/ExceptionTransparencyTest.kt index aca9eb9a1f..e5ffa5d831 100644 --- a/kotlinx-coroutines-core/jvm/test/flow/ExceptionTransparencyTest.kt +++ b/kotlinx-coroutines-core/jvm/test/flow/ExceptionTransparencyTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/flow/FirstJvmTest.kt b/kotlinx-coroutines-core/jvm/test/flow/FirstJvmTest.kt index 77ad0831f3..262bd9dceb 100644 --- a/kotlinx-coroutines-core/jvm/test/flow/FirstJvmTest.kt +++ b/kotlinx-coroutines-core/jvm/test/flow/FirstJvmTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/flow/FlatMapStressTest.kt b/kotlinx-coroutines-core/jvm/test/flow/FlatMapStressTest.kt index 699d9c6473..928474a9e3 100644 --- a/kotlinx-coroutines-core/jvm/test/flow/FlatMapStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/flow/FlatMapStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/flow/OnCompletionInterceptedReleaseTest.kt b/kotlinx-coroutines-core/jvm/test/flow/OnCompletionInterceptedReleaseTest.kt index a6268b5156..d293ead764 100644 --- a/kotlinx-coroutines-core/jvm/test/flow/OnCompletionInterceptedReleaseTest.kt +++ b/kotlinx-coroutines-core/jvm/test/flow/OnCompletionInterceptedReleaseTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/flow/SafeCollectorMemoryLeakTest.kt b/kotlinx-coroutines-core/jvm/test/flow/SafeCollectorMemoryLeakTest.kt index b75ec60ed5..36b28c5dc8 100644 --- a/kotlinx-coroutines-core/jvm/test/flow/SafeCollectorMemoryLeakTest.kt +++ b/kotlinx-coroutines-core/jvm/test/flow/SafeCollectorMemoryLeakTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/flow/SharedFlowStressTest.kt b/kotlinx-coroutines-core/jvm/test/flow/SharedFlowStressTest.kt index 58e3ef406f..fe90365a50 100644 --- a/kotlinx-coroutines-core/jvm/test/flow/SharedFlowStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/flow/SharedFlowStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/flow/SharingReferenceTest.kt b/kotlinx-coroutines-core/jvm/test/flow/SharingReferenceTest.kt index aba95edd32..46acaeb89d 100644 --- a/kotlinx-coroutines-core/jvm/test/flow/SharingReferenceTest.kt +++ b/kotlinx-coroutines-core/jvm/test/flow/SharingReferenceTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/flow/SharingStressTest.kt b/kotlinx-coroutines-core/jvm/test/flow/SharingStressTest.kt index 25c0c98314..0a7352bc87 100644 --- a/kotlinx-coroutines-core/jvm/test/flow/SharingStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/flow/SharingStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/flow/StateFlowCancellabilityTest.kt b/kotlinx-coroutines-core/jvm/test/flow/StateFlowCancellabilityTest.kt index fc4996c7c0..6f93199d25 100644 --- a/kotlinx-coroutines-core/jvm/test/flow/StateFlowCancellabilityTest.kt +++ b/kotlinx-coroutines-core/jvm/test/flow/StateFlowCancellabilityTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/flow/StateFlowStressTest.kt b/kotlinx-coroutines-core/jvm/test/flow/StateFlowStressTest.kt index e55eaad127..d69a88e03b 100644 --- a/kotlinx-coroutines-core/jvm/test/flow/StateFlowStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/flow/StateFlowStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/flow/StateFlowUpdateStressTest.kt b/kotlinx-coroutines-core/jvm/test/flow/StateFlowUpdateStressTest.kt index 660ed0aacd..2d85b2e7d6 100644 --- a/kotlinx-coroutines-core/jvm/test/flow/StateFlowUpdateStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/flow/StateFlowUpdateStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-basic-01.kt b/kotlinx-coroutines-core/jvm/test/guide/example-basic-01.kt index 529f881730..725beac447 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-basic-01.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-basic-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-basics.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleBasic01 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-basic-02.kt b/kotlinx-coroutines-core/jvm/test/guide/example-basic-02.kt index 6bf2af4c31..b0102060ed 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-basic-02.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-basic-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-basics.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleBasic02 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-basic-03.kt b/kotlinx-coroutines-core/jvm/test/guide/example-basic-03.kt index 67b6894ada..37ad624a96 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-basic-03.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-basic-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-basics.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleBasic03 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-basic-04.kt b/kotlinx-coroutines-core/jvm/test/guide/example-basic-04.kt index efac708530..bee0331ad2 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-basic-04.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-basic-04.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-basics.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleBasic04 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-basic-05.kt b/kotlinx-coroutines-core/jvm/test/guide/example-basic-05.kt index 193f2cc3aa..d9a29ac2dc 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-basic-05.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-basic-05.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-basics.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleBasic05 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-basic-06.kt b/kotlinx-coroutines-core/jvm/test/guide/example-basic-06.kt index 3c503ac1cb..c621cfb259 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-basic-06.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-basic-06.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-basics.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleBasic06 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-01.kt b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-01.kt index a1b036d91f..5a0d5a8b1a 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-01.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from cancellation-and-timeouts.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCancel01 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-02.kt b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-02.kt index f6dec6e8f4..3704051697 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-02.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from cancellation-and-timeouts.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCancel02 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-03.kt b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-03.kt index 2cf0770a7d..a950f80d80 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-03.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from cancellation-and-timeouts.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCancel03 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-04.kt b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-04.kt index 7d7f3bdee2..195c2ea739 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-04.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-04.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from cancellation-and-timeouts.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCancel04 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-05.kt b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-05.kt index 97ea956ec3..c82fb4ad0f 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-05.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-05.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from cancellation-and-timeouts.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCancel05 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-06.kt b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-06.kt index ef66f5df09..844db9879e 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-06.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-06.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from cancellation-and-timeouts.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCancel06 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-07.kt b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-07.kt index ea4a10353f..73d25748fe 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-07.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-07.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from cancellation-and-timeouts.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCancel07 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-08.kt b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-08.kt index 79d08091c2..29f3e10c7f 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-08.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-08.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from cancellation-and-timeouts.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCancel08 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-09.kt b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-09.kt index ecd5a942e3..5baa99f37d 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-09.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-09.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from cancellation-and-timeouts.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCancel09 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-10.kt b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-10.kt index 03dd852878..6cbc2e579a 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-cancel-10.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-cancel-10.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from cancellation-and-timeouts.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCancel10 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-channel-01.kt b/kotlinx-coroutines-core/jvm/test/guide/example-channel-01.kt index 0af1ebd311..d68c113bd2 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-channel-01.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-channel-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from channels.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleChannel01 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-channel-02.kt b/kotlinx-coroutines-core/jvm/test/guide/example-channel-02.kt index 33eb7b33dd..5a5a7547bd 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-channel-02.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-channel-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from channels.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleChannel02 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-channel-03.kt b/kotlinx-coroutines-core/jvm/test/guide/example-channel-03.kt index 4a2613be6a..9c69c62fff 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-channel-03.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-channel-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from channels.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleChannel03 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-channel-04.kt b/kotlinx-coroutines-core/jvm/test/guide/example-channel-04.kt index 73e8b6ce5f..da61e14c94 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-channel-04.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-channel-04.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from channels.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleChannel04 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-channel-05.kt b/kotlinx-coroutines-core/jvm/test/guide/example-channel-05.kt index 2143df579c..f8b2f369f5 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-channel-05.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-channel-05.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from channels.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleChannel05 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-channel-06.kt b/kotlinx-coroutines-core/jvm/test/guide/example-channel-06.kt index b78fcc90ef..1d61cea8cf 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-channel-06.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-channel-06.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from channels.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleChannel06 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-channel-07.kt b/kotlinx-coroutines-core/jvm/test/guide/example-channel-07.kt index 84de403dc9..f21274f11a 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-channel-07.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-channel-07.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from channels.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleChannel07 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-channel-08.kt b/kotlinx-coroutines-core/jvm/test/guide/example-channel-08.kt index eedf1c7a89..f5549cad4e 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-channel-08.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-channel-08.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from channels.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleChannel08 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-channel-09.kt b/kotlinx-coroutines-core/jvm/test/guide/example-channel-09.kt index 259f52eb8a..d93bc0e81e 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-channel-09.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-channel-09.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from channels.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleChannel09 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-channel-10.kt b/kotlinx-coroutines-core/jvm/test/guide/example-channel-10.kt index 1f48b02e4c..7e2b59bf1d 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-channel-10.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-channel-10.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from channels.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleChannel10 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-compose-01.kt b/kotlinx-coroutines-core/jvm/test/guide/example-compose-01.kt index ec20f1e40d..7194b64a26 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-compose-01.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-compose-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from composing-suspending-functions.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCompose01 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-compose-02.kt b/kotlinx-coroutines-core/jvm/test/guide/example-compose-02.kt index 9531b5c893..126004ca9b 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-compose-02.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-compose-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from composing-suspending-functions.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCompose02 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-compose-03.kt b/kotlinx-coroutines-core/jvm/test/guide/example-compose-03.kt index a61afeab55..04801c6ae4 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-compose-03.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-compose-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from composing-suspending-functions.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCompose03 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-compose-04.kt b/kotlinx-coroutines-core/jvm/test/guide/example-compose-04.kt index 35536a7d14..0d770452dc 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-compose-04.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-compose-04.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from composing-suspending-functions.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCompose04 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-compose-05.kt b/kotlinx-coroutines-core/jvm/test/guide/example-compose-05.kt index 37c4f99e6e..d32b5efb60 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-compose-05.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-compose-05.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from composing-suspending-functions.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCompose05 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-compose-06.kt b/kotlinx-coroutines-core/jvm/test/guide/example-compose-06.kt index 5ee9e451fb..1dbbc80c93 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-compose-06.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-compose-06.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from composing-suspending-functions.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleCompose06 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-context-01.kt b/kotlinx-coroutines-core/jvm/test/guide/example-context-01.kt index 0a9546057a..1c6a362a96 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-context-01.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-context-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutine-context-and-dispatchers.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleContext01 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-context-02.kt b/kotlinx-coroutines-core/jvm/test/guide/example-context-02.kt index 49bfe7efa3..3aa64e9725 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-context-02.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-context-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutine-context-and-dispatchers.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleContext02 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-context-03.kt b/kotlinx-coroutines-core/jvm/test/guide/example-context-03.kt index 3aaf0b30ad..696852cbee 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-context-03.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-context-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutine-context-and-dispatchers.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleContext03 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-context-04.kt b/kotlinx-coroutines-core/jvm/test/guide/example-context-04.kt index c5ce5eba7b..9609df83a2 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-context-04.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-context-04.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutine-context-and-dispatchers.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleContext04 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-context-05.kt b/kotlinx-coroutines-core/jvm/test/guide/example-context-05.kt index 3017b04996..e459561472 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-context-05.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-context-05.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutine-context-and-dispatchers.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleContext05 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-context-06.kt b/kotlinx-coroutines-core/jvm/test/guide/example-context-06.kt index 6796532229..a90e5216eb 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-context-06.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-context-06.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutine-context-and-dispatchers.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleContext06 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-context-07.kt b/kotlinx-coroutines-core/jvm/test/guide/example-context-07.kt index 8037a559c5..847009671d 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-context-07.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-context-07.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutine-context-and-dispatchers.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleContext07 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-context-08.kt b/kotlinx-coroutines-core/jvm/test/guide/example-context-08.kt index a34e1aea5c..0ab1a3ee48 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-context-08.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-context-08.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutine-context-and-dispatchers.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleContext08 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-context-09.kt b/kotlinx-coroutines-core/jvm/test/guide/example-context-09.kt index 6c1121b2a3..a4f730b70a 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-context-09.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-context-09.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutine-context-and-dispatchers.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleContext09 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-context-10.kt b/kotlinx-coroutines-core/jvm/test/guide/example-context-10.kt index 73ecbd2b3e..d1385a993f 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-context-10.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-context-10.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutine-context-and-dispatchers.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleContext10 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-context-11.kt b/kotlinx-coroutines-core/jvm/test/guide/example-context-11.kt index e3563171f5..2b0a521812 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-context-11.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-context-11.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutine-context-and-dispatchers.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleContext11 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-01.kt b/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-01.kt index 24cbabe094..a6ae6cac0f 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-01.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from exception-handling.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleExceptions01 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-02.kt b/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-02.kt index c3ab68a53a..c619d7998d 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-02.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from exception-handling.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleExceptions02 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-03.kt b/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-03.kt index 1ad5aef719..02bd6b8721 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-03.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from exception-handling.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleExceptions03 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-04.kt b/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-04.kt index b966c1eab4..cb8b4ff6ad 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-04.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-04.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from exception-handling.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleExceptions04 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-05.kt b/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-05.kt index 5f1f3d89a9..c7e543d25f 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-05.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-05.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from exception-handling.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleExceptions05 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-06.kt b/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-06.kt index c1374f787c..5d88a1ed1b 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-06.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-exceptions-06.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from exception-handling.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleExceptions06 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-01.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-01.kt index 7c6c1578f8..8db2596892 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-01.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow01 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-02.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-02.kt index e3fabe37f8..1162b1eb9c 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-02.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow02 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-03.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-03.kt index 61601dd94d..57e466fdf6 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-03.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow03 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-04.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-04.kt index c91f70403e..9efed63b34 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-04.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-04.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow04 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-05.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-05.kt index 788d941d53..93fcb194f4 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-05.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-05.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow05 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-06.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-06.kt index bd4058e757..8abc161340 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-06.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-06.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow06 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-07.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-07.kt index 73b1734208..03e2d2e860 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-07.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-07.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow07 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-08.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-08.kt index 1e8580c81f..c834439d69 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-08.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-08.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow08 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-09.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-09.kt index 7e2113c401..a151946239 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-09.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-09.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow09 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-10.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-10.kt index 61e74a1aa1..03981b6612 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-10.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-10.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow10 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-11.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-11.kt index 513057d10b..74359206cd 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-11.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-11.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow11 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-12.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-12.kt index 54ddf659f3..806d2b8760 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-12.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-12.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow12 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-13.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-13.kt index 945ce8954d..2ff0d084eb 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-13.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-13.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow13 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-14.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-14.kt index b5fc35e24e..26d2b4956e 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-14.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-14.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow14 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-15.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-15.kt index 0218e99532..1a6e0fd374 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-15.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-15.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow15 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-16.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-16.kt index 7f3414fff4..35ec7a27d3 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-16.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-16.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow16 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-17.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-17.kt index ed7161783f..4048f437f3 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-17.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-17.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow17 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-18.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-18.kt index fc7bdef561..61779b3809 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-18.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-18.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow18 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-19.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-19.kt index f4ee2193c0..82b02699fa 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-19.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-19.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow19 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-20.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-20.kt index bb829d11a0..f0d68019c7 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-20.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-20.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow20 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-21.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-21.kt index e0adea60b5..9c3c22d16b 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-21.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-21.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow21 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-22.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-22.kt index 9450ce59a9..9cf2734b60 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-22.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-22.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow22 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-23.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-23.kt index 973f3638e6..4ff44881cb 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-23.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-23.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow23 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-24.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-24.kt index 7da20e01a6..f4132be50b 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-24.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-24.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow24 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-25.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-25.kt index e3c2b812cd..a09def0018 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-25.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-25.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow25 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-26.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-26.kt index 95f9a113b5..1297f3f02c 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-26.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-26.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow26 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-27.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-27.kt index 3f34a7674f..29ed17cf13 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-27.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-27.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow27 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-28.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-28.kt index 02b231e985..6514f157da 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-28.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-28.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow28 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-29.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-29.kt index 5ec37afd1e..536660af19 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-29.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-29.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow29 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-30.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-30.kt index e787ca39ae..0cff2ab142 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-30.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-30.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow30 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-31.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-31.kt index 19fcb1c626..4f833f5bf2 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-31.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-31.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow31 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-32.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-32.kt index 984895753d..d0079934f1 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-32.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-32.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow32 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-33.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-33.kt index 9f86765afd..0d4f7f0544 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-33.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-33.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow33 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-34.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-34.kt index b2cee7f9fb..f27545dd9d 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-34.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-34.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow34 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-35.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-35.kt index 928c8bf2e6..a2b15e87df 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-35.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-35.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow35 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-36.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-36.kt index 3138464ced..c58035bcdc 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-36.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-36.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow36 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-37.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-37.kt index 229e55b130..6d35f6ff79 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-37.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-37.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow37 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-38.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-38.kt index fcbbb24ef7..169a3fde7b 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-38.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-38.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow38 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-flow-39.kt b/kotlinx-coroutines-core/jvm/test/guide/example-flow-39.kt index 86275c7c4a..a79e8a55c5 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-flow-39.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-flow-39.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleFlow39 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-select-01.kt b/kotlinx-coroutines-core/jvm/test/guide/example-select-01.kt index bf15b65507..5bc6710817 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-select-01.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-select-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from select-expression.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSelect01 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-select-02.kt b/kotlinx-coroutines-core/jvm/test/guide/example-select-02.kt index 22380d3af5..3aa101a7c1 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-select-02.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-select-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from select-expression.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSelect02 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-select-03.kt b/kotlinx-coroutines-core/jvm/test/guide/example-select-03.kt index 36597dd637..c9f3d37e74 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-select-03.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-select-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from select-expression.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSelect03 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-select-04.kt b/kotlinx-coroutines-core/jvm/test/guide/example-select-04.kt index 4cd9f6d93f..4837957b7f 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-select-04.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-select-04.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from select-expression.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSelect04 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-select-05.kt b/kotlinx-coroutines-core/jvm/test/guide/example-select-05.kt index 68b4456454..c8b2e9987b 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-select-05.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-select-05.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from select-expression.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSelect05 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-supervision-01.kt b/kotlinx-coroutines-core/jvm/test/guide/example-supervision-01.kt index db819e4fc6..a5cd1fd13f 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-supervision-01.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-supervision-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from exception-handling.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSupervision01 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-supervision-02.kt b/kotlinx-coroutines-core/jvm/test/guide/example-supervision-02.kt index 50deff3d0b..3c82527b8f 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-supervision-02.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-supervision-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from exception-handling.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSupervision02 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-supervision-03.kt b/kotlinx-coroutines-core/jvm/test/guide/example-supervision-03.kt index 943c64f6ee..e23fe7f2db 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-supervision-03.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-supervision-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from exception-handling.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSupervision03 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-sync-01.kt b/kotlinx-coroutines-core/jvm/test/guide/example-sync-01.kt index 32d4ac4fe9..69c01b7cb8 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-sync-01.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-sync-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from shared-mutable-state-and-concurrency.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSync01 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-sync-02.kt b/kotlinx-coroutines-core/jvm/test/guide/example-sync-02.kt index fb551f8953..971c6e52e5 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-sync-02.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-sync-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from shared-mutable-state-and-concurrency.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSync02 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-sync-03.kt b/kotlinx-coroutines-core/jvm/test/guide/example-sync-03.kt index 8153c026b4..e3b3b94814 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-sync-03.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-sync-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from shared-mutable-state-and-concurrency.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSync03 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-sync-04.kt b/kotlinx-coroutines-core/jvm/test/guide/example-sync-04.kt index f94c4a05da..382a834793 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-sync-04.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-sync-04.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from shared-mutable-state-and-concurrency.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSync04 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-sync-05.kt b/kotlinx-coroutines-core/jvm/test/guide/example-sync-05.kt index a6a1cdd2a6..597674ae2f 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-sync-05.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-sync-05.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from shared-mutable-state-and-concurrency.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSync05 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-sync-06.kt b/kotlinx-coroutines-core/jvm/test/guide/example-sync-06.kt index e6c5f1bad3..4fc77676bf 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-sync-06.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-sync-06.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from shared-mutable-state-and-concurrency.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSync06 diff --git a/kotlinx-coroutines-core/jvm/test/guide/example-sync-07.kt b/kotlinx-coroutines-core/jvm/test/guide/example-sync-07.kt index a84e02c849..14c452c2f7 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/example-sync-07.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/example-sync-07.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from shared-mutable-state-and-concurrency.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.exampleSync07 diff --git a/kotlinx-coroutines-core/jvm/test/guide/test/BasicsGuideTest.kt b/kotlinx-coroutines-core/jvm/test/guide/test/BasicsGuideTest.kt index 550f8e7b24..8452f4344e 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/test/BasicsGuideTest.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/test/BasicsGuideTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-basics.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.test diff --git a/kotlinx-coroutines-core/jvm/test/guide/test/CancellationGuideTest.kt b/kotlinx-coroutines-core/jvm/test/guide/test/CancellationGuideTest.kt index 871e4911e8..f09b762288 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/test/CancellationGuideTest.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/test/CancellationGuideTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from cancellation-and-timeouts.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.test diff --git a/kotlinx-coroutines-core/jvm/test/guide/test/ChannelsGuideTest.kt b/kotlinx-coroutines-core/jvm/test/guide/test/ChannelsGuideTest.kt index d15a550adb..c2798a3335 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/test/ChannelsGuideTest.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/test/ChannelsGuideTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from channels.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.test diff --git a/kotlinx-coroutines-core/jvm/test/guide/test/ComposingGuideTest.kt b/kotlinx-coroutines-core/jvm/test/guide/test/ComposingGuideTest.kt index 1f9692d56b..26682765e7 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/test/ComposingGuideTest.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/test/ComposingGuideTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from composing-suspending-functions.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.test diff --git a/kotlinx-coroutines-core/jvm/test/guide/test/DispatcherGuideTest.kt b/kotlinx-coroutines-core/jvm/test/guide/test/DispatcherGuideTest.kt index e18741e981..5a4bb9939c 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/test/DispatcherGuideTest.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/test/DispatcherGuideTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutine-context-and-dispatchers.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.test diff --git a/kotlinx-coroutines-core/jvm/test/guide/test/ExceptionsGuideTest.kt b/kotlinx-coroutines-core/jvm/test/guide/test/ExceptionsGuideTest.kt index f34fd3f83b..33da0a7bc7 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/test/ExceptionsGuideTest.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/test/ExceptionsGuideTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from exception-handling.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.test diff --git a/kotlinx-coroutines-core/jvm/test/guide/test/FlowGuideTest.kt b/kotlinx-coroutines-core/jvm/test/guide/test/FlowGuideTest.kt index c7d4a72082..4735a9ce19 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/test/FlowGuideTest.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/test/FlowGuideTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from flow.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.test diff --git a/kotlinx-coroutines-core/jvm/test/guide/test/SelectGuideTest.kt b/kotlinx-coroutines-core/jvm/test/guide/test/SelectGuideTest.kt index 8bc81913d7..d0e879e01e 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/test/SelectGuideTest.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/test/SelectGuideTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from select-expression.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.test diff --git a/kotlinx-coroutines-core/jvm/test/guide/test/SharedStateGuideTest.kt b/kotlinx-coroutines-core/jvm/test/guide/test/SharedStateGuideTest.kt index 034b82efc9..7e43650bf6 100644 --- a/kotlinx-coroutines-core/jvm/test/guide/test/SharedStateGuideTest.kt +++ b/kotlinx-coroutines-core/jvm/test/guide/test/SharedStateGuideTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from shared-mutable-state-and-concurrency.md by Knit tool. Do not edit. package kotlinx.coroutines.guide.test diff --git a/kotlinx-coroutines-core/jvm/test/internal/ConcurrentWeakMapCollectionStressTest.kt b/kotlinx-coroutines-core/jvm/test/internal/ConcurrentWeakMapCollectionStressTest.kt index d9a2a96d81..ff9c8f7a0d 100644 --- a/kotlinx-coroutines-core/jvm/test/internal/ConcurrentWeakMapCollectionStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/internal/ConcurrentWeakMapCollectionStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import junit.framework.Assert.* diff --git a/kotlinx-coroutines-core/jvm/test/internal/ConcurrentWeakMapOperationStressTest.kt b/kotlinx-coroutines-core/jvm/test/internal/ConcurrentWeakMapOperationStressTest.kt index 63b5838442..ae58a384de 100644 --- a/kotlinx-coroutines-core/jvm/test/internal/ConcurrentWeakMapOperationStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/internal/ConcurrentWeakMapOperationStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/internal/ConcurrentWeakMapTest.kt b/kotlinx-coroutines-core/jvm/test/internal/ConcurrentWeakMapTest.kt index e4fa5e9bfe..dbeb77bd6e 100644 --- a/kotlinx-coroutines-core/jvm/test/internal/ConcurrentWeakMapTest.kt +++ b/kotlinx-coroutines-core/jvm/test/internal/ConcurrentWeakMapTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import junit.framework.Assert.* diff --git a/kotlinx-coroutines-core/jvm/test/internal/LockFreeLinkedListLongStressTest.kt b/kotlinx-coroutines-core/jvm/test/internal/LockFreeLinkedListLongStressTest.kt index e367e6b37c..fd44d5de59 100644 --- a/kotlinx-coroutines-core/jvm/test/internal/LockFreeLinkedListLongStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/internal/LockFreeLinkedListLongStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.TestBase diff --git a/kotlinx-coroutines-core/jvm/test/internal/LockFreeTaskQueueStressTest.kt b/kotlinx-coroutines-core/jvm/test/internal/LockFreeTaskQueueStressTest.kt index 16e436efd1..f4c4e9bc0e 100644 --- a/kotlinx-coroutines-core/jvm/test/internal/LockFreeTaskQueueStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/internal/LockFreeTaskQueueStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/internal/LockFreeTaskQueueTest.kt b/kotlinx-coroutines-core/jvm/test/internal/LockFreeTaskQueueTest.kt index 29f019bd91..5be63f76ab 100644 --- a/kotlinx-coroutines-core/jvm/test/internal/LockFreeTaskQueueTest.kt +++ b/kotlinx-coroutines-core/jvm/test/internal/LockFreeTaskQueueTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/internal/OnDemandAllocatingPoolLincheckTest.kt b/kotlinx-coroutines-core/jvm/test/internal/OnDemandAllocatingPoolLincheckTest.kt index 9655890c4f..34f9780a27 100644 --- a/kotlinx-coroutines-core/jvm/test/internal/OnDemandAllocatingPoolLincheckTest.kt +++ b/kotlinx-coroutines-core/jvm/test/internal/OnDemandAllocatingPoolLincheckTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/internal/ThreadSafeHeapStressTest.kt b/kotlinx-coroutines-core/jvm/test/internal/ThreadSafeHeapStressTest.kt index 5bc0952ed4..742043fa1c 100644 --- a/kotlinx-coroutines-core/jvm/test/internal/ThreadSafeHeapStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/internal/ThreadSafeHeapStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/internal/ThreadSafeHeapTest.kt b/kotlinx-coroutines-core/jvm/test/internal/ThreadSafeHeapTest.kt index ee0960c849..0fb583c2c2 100644 --- a/kotlinx-coroutines-core/jvm/test/internal/ThreadSafeHeapTest.kt +++ b/kotlinx-coroutines-core/jvm/test/internal/ThreadSafeHeapTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/jdk8/future/AsFutureTest.kt b/kotlinx-coroutines-core/jvm/test/jdk8/future/AsFutureTest.kt index 743816fa85..afde06c3c6 100644 --- a/kotlinx-coroutines-core/jvm/test/jdk8/future/AsFutureTest.kt +++ b/kotlinx-coroutines-core/jvm/test/jdk8/future/AsFutureTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.future import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureAsDeferredUnhandledCompletionExceptionTest.kt b/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureAsDeferredUnhandledCompletionExceptionTest.kt index 9c9c97ecdf..ebd95f5be1 100644 --- a/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureAsDeferredUnhandledCompletionExceptionTest.kt +++ b/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureAsDeferredUnhandledCompletionExceptionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.future import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureExceptionsTest.kt b/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureExceptionsTest.kt index 0c919b1846..a714f1e863 100644 --- a/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureExceptionsTest.kt +++ b/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureExceptionsTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.future import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureTest.kt b/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureTest.kt index 6311538e9f..13af7f13b9 100644 --- a/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureTest.kt +++ b/kotlinx-coroutines-core/jvm/test/jdk8/future/FutureTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.future import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/jdk8/stream/ConsumeAsFlowTest.kt b/kotlinx-coroutines-core/jvm/test/jdk8/stream/ConsumeAsFlowTest.kt index 96ff963d61..38f4c57ad2 100644 --- a/kotlinx-coroutines-core/jvm/test/jdk8/stream/ConsumeAsFlowTest.kt +++ b/kotlinx-coroutines-core/jvm/test/jdk8/stream/ConsumeAsFlowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.stream import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/jdk8/time/DurationOverflowTest.kt b/kotlinx-coroutines-core/jvm/test/jdk8/time/DurationOverflowTest.kt index 9ab0ccf95f..42adef8623 100644 --- a/kotlinx-coroutines-core/jvm/test/jdk8/time/DurationOverflowTest.kt +++ b/kotlinx-coroutines-core/jvm/test/jdk8/time/DurationOverflowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.time import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/jdk8/time/FlowDebounceTest.kt b/kotlinx-coroutines-core/jvm/test/jdk8/time/FlowDebounceTest.kt index d6b2b8c105..c0b442dfc9 100644 --- a/kotlinx-coroutines-core/jvm/test/jdk8/time/FlowDebounceTest.kt +++ b/kotlinx-coroutines-core/jvm/test/jdk8/time/FlowDebounceTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.time import kotlinx.coroutines.TestBase diff --git a/kotlinx-coroutines-core/jvm/test/jdk8/time/FlowSampleTest.kt b/kotlinx-coroutines-core/jvm/test/jdk8/time/FlowSampleTest.kt index d35ee72de0..c51cedf9c2 100644 --- a/kotlinx-coroutines-core/jvm/test/jdk8/time/FlowSampleTest.kt +++ b/kotlinx-coroutines-core/jvm/test/jdk8/time/FlowSampleTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.time import kotlinx.coroutines.TestBase diff --git a/kotlinx-coroutines-core/jvm/test/jdk8/time/WithTimeoutTest.kt b/kotlinx-coroutines-core/jvm/test/jdk8/time/WithTimeoutTest.kt index d33eaac124..7ebe99485e 100644 --- a/kotlinx-coroutines-core/jvm/test/jdk8/time/WithTimeoutTest.kt +++ b/kotlinx-coroutines-core/jvm/test/jdk8/time/WithTimeoutTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.time import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/knit/ClosedAfterGuideTestExecutor.kt b/kotlinx-coroutines-core/jvm/test/knit/ClosedAfterGuideTestExecutor.kt index 30fbfee264..e5127d6a5a 100644 --- a/kotlinx-coroutines-core/jvm/test/knit/ClosedAfterGuideTestExecutor.kt +++ b/kotlinx-coroutines-core/jvm/test/knit/ClosedAfterGuideTestExecutor.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines // Trick to make guide tests use these declarations with executors that can be closed on our side implicitly import java.util.concurrent.* diff --git a/kotlinx-coroutines-core/jvm/test/knit/TestUtil.kt b/kotlinx-coroutines-core/jvm/test/knit/TestUtil.kt index 80c98030d9..85d798690e 100644 --- a/kotlinx-coroutines-core/jvm/test/knit/TestUtil.kt +++ b/kotlinx-coroutines-core/jvm/test/knit/TestUtil.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.knit import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/lincheck/ChannelsLincheckTest.kt b/kotlinx-coroutines-core/jvm/test/lincheck/ChannelsLincheckTest.kt index 092ef6fc52..4391ce6a86 100644 --- a/kotlinx-coroutines-core/jvm/test/lincheck/ChannelsLincheckTest.kt +++ b/kotlinx-coroutines-core/jvm/test/lincheck/ChannelsLincheckTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("unused", "MemberVisibilityCanBePrivate") package kotlinx.coroutines.lincheck diff --git a/kotlinx-coroutines-core/jvm/test/lincheck/LockFreeTaskQueueLincheckTest.kt b/kotlinx-coroutines-core/jvm/test/lincheck/LockFreeTaskQueueLincheckTest.kt index 11f5535b5a..9a44891733 100644 --- a/kotlinx-coroutines-core/jvm/test/lincheck/LockFreeTaskQueueLincheckTest.kt +++ b/kotlinx-coroutines-core/jvm/test/lincheck/LockFreeTaskQueueLincheckTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("unused") package kotlinx.coroutines.lincheck diff --git a/kotlinx-coroutines-core/jvm/test/lincheck/MutexLincheckTest.kt b/kotlinx-coroutines-core/jvm/test/lincheck/MutexLincheckTest.kt index 983a64acda..37051794b0 100644 --- a/kotlinx-coroutines-core/jvm/test/lincheck/MutexLincheckTest.kt +++ b/kotlinx-coroutines-core/jvm/test/lincheck/MutexLincheckTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("unused") package kotlinx.coroutines.lincheck diff --git a/kotlinx-coroutines-core/jvm/test/lincheck/ResizableAtomicArrayLincheckTest.kt b/kotlinx-coroutines-core/jvm/test/lincheck/ResizableAtomicArrayLincheckTest.kt index e937b37e08..5561a7dbf3 100644 --- a/kotlinx-coroutines-core/jvm/test/lincheck/ResizableAtomicArrayLincheckTest.kt +++ b/kotlinx-coroutines-core/jvm/test/lincheck/ResizableAtomicArrayLincheckTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.lincheck import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/lincheck/SemaphoreLincheckTest.kt b/kotlinx-coroutines-core/jvm/test/lincheck/SemaphoreLincheckTest.kt index d093e8066a..94a521baa9 100644 --- a/kotlinx-coroutines-core/jvm/test/lincheck/SemaphoreLincheckTest.kt +++ b/kotlinx-coroutines-core/jvm/test/lincheck/SemaphoreLincheckTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("unused") package kotlinx.coroutines.lincheck diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherLivenessStressTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherLivenessStressTest.kt index 7fc212f59f..83e925e67e 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherLivenessStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherLivenessStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherMixedStealingStressTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherMixedStealingStressTest.kt index 3a55f8c4f2..2b8dacb92e 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherMixedStealingStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherMixedStealingStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherTerminationStressTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherTerminationStressTest.kt index 864ecdc087..f947ddc99f 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherTerminationStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherTerminationStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.scheduling.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherTest.kt index f8830feeef..b994cef389 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherThreadLimitStressTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherThreadLimitStressTest.kt index c1fda44487..13efa3f01a 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherThreadLimitStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherThreadLimitStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherWorkSignallingStressTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherWorkSignallingStressTest.kt index 3b3e085047..8b9c7e51fa 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherWorkSignallingStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/BlockingCoroutineDispatcherWorkSignallingStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("DeferredResultUnused") package kotlinx.coroutines.scheduling diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineDispatcherTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineDispatcherTest.kt index c95415a8df..398d1150f7 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineDispatcherTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineDispatcherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerCloseStressTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerCloseStressTest.kt index a50867d61c..9e3fff80c9 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerCloseStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerCloseStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerInternalApiStressTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerInternalApiStressTest.kt index 2ec714ffb6..db71afc2d1 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerInternalApiStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerInternalApiStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerLivenessStressTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerLivenessStressTest.kt index b7677bef29..c014f536fc 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerLivenessStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerLivenessStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerOversubscriptionTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerOversubscriptionTest.kt index 0fd6159f9e..d6c023b4c1 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerOversubscriptionTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerOversubscriptionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerStressTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerStressTest.kt index 7aefd4f75c..0b91e491e6 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerTest.kt index 9d41c05d26..ef3640ec5b 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/CoroutineSchedulerTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/DefaultDispatchersTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/DefaultDispatchersTest.kt index 56c669547c..bee35d3efd 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/DefaultDispatchersTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/DefaultDispatchersTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/LimitingCoroutineDispatcherStressTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/LimitingCoroutineDispatcherStressTest.kt index 0123ac5db8..6b3f932207 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/LimitingCoroutineDispatcherStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/LimitingCoroutineDispatcherStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/LimitingDispatcherTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/LimitingDispatcherTest.kt index e5705803c0..b4baaf94f3 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/LimitingDispatcherTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/LimitingDispatcherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/SchedulerTestBase.kt b/kotlinx-coroutines-core/jvm/test/scheduling/SchedulerTestBase.kt index fc4436f418..c9ea624902 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/SchedulerTestBase.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/SchedulerTestBase.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("UNUSED_VARIABLE") package kotlinx.coroutines.scheduling diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/SharingWorkerClassTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/SharingWorkerClassTest.kt index 743b4a617f..e1c3a83127 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/SharingWorkerClassTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/SharingWorkerClassTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/TestTimeSource.kt b/kotlinx-coroutines-core/jvm/test/scheduling/TestTimeSource.kt index 233e442098..39df9a606a 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/TestTimeSource.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/TestTimeSource.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/WorkQueueStressTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/WorkQueueStressTest.kt index e2562b57ba..17a781906a 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/WorkQueueStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/WorkQueueStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/scheduling/WorkQueueTest.kt b/kotlinx-coroutines-core/jvm/test/scheduling/WorkQueueTest.kt index f690d3882f..3aabb3ed72 100644 --- a/kotlinx-coroutines-core/jvm/test/scheduling/WorkQueueTest.kt +++ b/kotlinx-coroutines-core/jvm/test/scheduling/WorkQueueTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.scheduling import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/selects/SelectDeadlockStressTest.kt b/kotlinx-coroutines-core/jvm/test/selects/SelectDeadlockStressTest.kt index d8d4b228c4..52925941eb 100644 --- a/kotlinx-coroutines-core/jvm/test/selects/SelectDeadlockStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/selects/SelectDeadlockStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/selects/SelectMemoryLeakStressTest.kt b/kotlinx-coroutines-core/jvm/test/selects/SelectMemoryLeakStressTest.kt index 2ddf133f00..07203d9bea 100644 --- a/kotlinx-coroutines-core/jvm/test/selects/SelectMemoryLeakStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/selects/SelectMemoryLeakStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvm/test/selects/SelectPhilosophersStressTest.kt b/kotlinx-coroutines-core/jvm/test/selects/SelectPhilosophersStressTest.kt index 22179f34ad..5c1ca952db 100644 --- a/kotlinx-coroutines-core/jvm/test/selects/SelectPhilosophersStressTest.kt +++ b/kotlinx-coroutines-core/jvm/test/selects/SelectPhilosophersStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.selects import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/BenchmarkUtils.kt b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/BenchmarkUtils.kt index 714aad114c..f0fdd82464 100644 --- a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/BenchmarkUtils.kt +++ b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/BenchmarkUtils.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import java.util.concurrent.* diff --git a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/SemaphoreBenchmark.kt b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/SemaphoreBenchmark.kt index df82690771..9fe895e88c 100644 --- a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/SemaphoreBenchmark.kt +++ b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/SemaphoreBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/ChannelProducerConsumerBenchmark.kt b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/ChannelProducerConsumerBenchmark.kt index 7bc0d2b2be..e7d01bcbef 100644 --- a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/ChannelProducerConsumerBenchmark.kt +++ b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/ChannelProducerConsumerBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/SelectBenchmark.kt b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/SelectBenchmark.kt index e2bc9e4abf..0df0c5971c 100644 --- a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/SelectBenchmark.kt +++ b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/SelectBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/SimpleChannel.kt b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/SimpleChannel.kt index 1afb0f0464..e198ea6934 100644 --- a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/SimpleChannel.kt +++ b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/SimpleChannel.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/SimpleChannelBenchmark.kt b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/SimpleChannelBenchmark.kt index 233cecff4e..3228687c0d 100644 --- a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/SimpleChannelBenchmark.kt +++ b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/channels/SimpleChannelBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.channels import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/flow/TakeWhileBenchmark.kt b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/flow/TakeWhileBenchmark.kt index 6dad29e51f..bdaabc3afa 100644 --- a/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/flow/TakeWhileBenchmark.kt +++ b/kotlinx-coroutines-core/jvmBenchmark/kotlin/kotlinx/coroutines/flow/TakeWhileBenchmark.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/knit.properties b/kotlinx-coroutines-core/knit.properties index 5b57398b8d..f27241a43c 100644 --- a/kotlinx-coroutines-core/knit.properties +++ b/kotlinx-coroutines-core/knit.properties @@ -1,7 +1,3 @@ -# -# Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. -# - knit.package=kotlinx.coroutines.examples knit.dir=jvm/test/examples/ diff --git a/kotlinx-coroutines-core/native/src/Builders.kt b/kotlinx-coroutines-core/native/src/Builders.kt index e3db7f16bc..a49ba6c53d 100644 --- a/kotlinx-coroutines-core/native/src/Builders.kt +++ b/kotlinx-coroutines-core/native/src/Builders.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:OptIn(ExperimentalContracts::class, ObsoleteWorkersApi::class) package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/native/src/CloseableCoroutineDispatcher.kt b/kotlinx-coroutines-core/native/src/CloseableCoroutineDispatcher.kt index 0e239a42f7..81e0c5d8c3 100644 --- a/kotlinx-coroutines-core/native/src/CloseableCoroutineDispatcher.kt +++ b/kotlinx-coroutines-core/native/src/CloseableCoroutineDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines public actual abstract class CloseableCoroutineDispatcher actual constructor() : CoroutineDispatcher() { diff --git a/kotlinx-coroutines-core/native/src/CoroutineContext.kt b/kotlinx-coroutines-core/native/src/CoroutineContext.kt index d751f0672e..70064e2d76 100644 --- a/kotlinx-coroutines-core/native/src/CoroutineContext.kt +++ b/kotlinx-coroutines-core/native/src/CoroutineContext.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/native/src/Debug.kt b/kotlinx-coroutines-core/native/src/Debug.kt index f17c2ed7fc..3cf24889d9 100644 --- a/kotlinx-coroutines-core/native/src/Debug.kt +++ b/kotlinx-coroutines-core/native/src/Debug.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.math.* diff --git a/kotlinx-coroutines-core/native/src/Dispatchers.kt b/kotlinx-coroutines-core/native/src/Dispatchers.kt index 2576ba5cf0..9965186303 100644 --- a/kotlinx-coroutines-core/native/src/Dispatchers.kt +++ b/kotlinx-coroutines-core/native/src/Dispatchers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/native/src/EventLoop.kt b/kotlinx-coroutines-core/native/src/EventLoop.kt index 62e51b26c7..e457842e34 100644 --- a/kotlinx-coroutines-core/native/src/EventLoop.kt +++ b/kotlinx-coroutines-core/native/src/EventLoop.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:OptIn(ObsoleteWorkersApi::class) package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/native/src/Exceptions.kt b/kotlinx-coroutines-core/native/src/Exceptions.kt index 30c5b26bbb..c6173afc26 100644 --- a/kotlinx-coroutines-core/native/src/Exceptions.kt +++ b/kotlinx-coroutines-core/native/src/Exceptions.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines /** diff --git a/kotlinx-coroutines-core/native/src/MultithreadedDispatchers.kt b/kotlinx-coroutines-core/native/src/MultithreadedDispatchers.kt index 548602e146..283fce0d0b 100644 --- a/kotlinx-coroutines-core/native/src/MultithreadedDispatchers.kt +++ b/kotlinx-coroutines-core/native/src/MultithreadedDispatchers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:OptIn(ObsoleteWorkersApi::class) package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/native/src/Runnable.kt b/kotlinx-coroutines-core/native/src/Runnable.kt index b8e6980b22..1a9e0ae7a0 100644 --- a/kotlinx-coroutines-core/native/src/Runnable.kt +++ b/kotlinx-coroutines-core/native/src/Runnable.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines /** diff --git a/kotlinx-coroutines-core/native/src/SchedulerTask.kt b/kotlinx-coroutines-core/native/src/SchedulerTask.kt index 9b2b68a02a..229302b075 100644 --- a/kotlinx-coroutines-core/native/src/SchedulerTask.kt +++ b/kotlinx-coroutines-core/native/src/SchedulerTask.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines internal actual abstract class SchedulerTask : Runnable diff --git a/kotlinx-coroutines-core/native/src/flow/internal/FlowExceptions.kt b/kotlinx-coroutines-core/native/src/flow/internal/FlowExceptions.kt index bc7a1ffc26..ebb47015ec 100644 --- a/kotlinx-coroutines-core/native/src/flow/internal/FlowExceptions.kt +++ b/kotlinx-coroutines-core/native/src/flow/internal/FlowExceptions.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/native/src/flow/internal/SafeCollector.kt b/kotlinx-coroutines-core/native/src/flow/internal/SafeCollector.kt index 483eee0c04..ded11e22f5 100644 --- a/kotlinx-coroutines-core/native/src/flow/internal/SafeCollector.kt +++ b/kotlinx-coroutines-core/native/src/flow/internal/SafeCollector.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.flow.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/native/src/internal/Concurrent.kt b/kotlinx-coroutines-core/native/src/internal/Concurrent.kt index 5bf002772a..8df5c52a13 100644 --- a/kotlinx-coroutines-core/native/src/internal/Concurrent.kt +++ b/kotlinx-coroutines-core/native/src/internal/Concurrent.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/native/src/internal/CopyOnWriteList.kt b/kotlinx-coroutines-core/native/src/internal/CopyOnWriteList.kt index 2896c2eac5..32e1c4ac94 100644 --- a/kotlinx-coroutines-core/native/src/internal/CopyOnWriteList.kt +++ b/kotlinx-coroutines-core/native/src/internal/CopyOnWriteList.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/native/src/internal/CoroutineExceptionHandlerImpl.kt b/kotlinx-coroutines-core/native/src/internal/CoroutineExceptionHandlerImpl.kt index 43d776cb54..621b8a9c08 100644 --- a/kotlinx-coroutines-core/native/src/internal/CoroutineExceptionHandlerImpl.kt +++ b/kotlinx-coroutines-core/native/src/internal/CoroutineExceptionHandlerImpl.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/native/src/internal/LocalAtomics.kt b/kotlinx-coroutines-core/native/src/internal/LocalAtomics.kt index c8c6fffe00..cbbeec1eed 100644 --- a/kotlinx-coroutines-core/native/src/internal/LocalAtomics.kt +++ b/kotlinx-coroutines-core/native/src/internal/LocalAtomics.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/native/src/internal/ProbesSupport.kt b/kotlinx-coroutines-core/native/src/internal/ProbesSupport.kt index 47d3fdbac9..00581f1c91 100644 --- a/kotlinx-coroutines-core/native/src/internal/ProbesSupport.kt +++ b/kotlinx-coroutines-core/native/src/internal/ProbesSupport.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/native/src/internal/StackTraceRecovery.kt b/kotlinx-coroutines-core/native/src/internal/StackTraceRecovery.kt index 903a6240a8..9c6df6b604 100644 --- a/kotlinx-coroutines-core/native/src/internal/StackTraceRecovery.kt +++ b/kotlinx-coroutines-core/native/src/internal/StackTraceRecovery.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/native/src/internal/Synchronized.kt b/kotlinx-coroutines-core/native/src/internal/Synchronized.kt index 20fc666229..3a4b0cf8e8 100644 --- a/kotlinx-coroutines-core/native/src/internal/Synchronized.kt +++ b/kotlinx-coroutines-core/native/src/internal/Synchronized.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.cinterop.* diff --git a/kotlinx-coroutines-core/native/src/internal/SystemProps.kt b/kotlinx-coroutines-core/native/src/internal/SystemProps.kt index 4fb334ed16..accc247d37 100644 --- a/kotlinx-coroutines-core/native/src/internal/SystemProps.kt +++ b/kotlinx-coroutines-core/native/src/internal/SystemProps.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal internal actual fun systemProp(propertyName: String): String? = null diff --git a/kotlinx-coroutines-core/native/src/internal/ThreadContext.kt b/kotlinx-coroutines-core/native/src/internal/ThreadContext.kt index 2370e42ff4..3f56f99d6c 100644 --- a/kotlinx-coroutines-core/native/src/internal/ThreadContext.kt +++ b/kotlinx-coroutines-core/native/src/internal/ThreadContext.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/native/src/internal/ThreadLocal.kt b/kotlinx-coroutines-core/native/src/internal/ThreadLocal.kt index 95069ec14d..0c803a7e36 100644 --- a/kotlinx-coroutines-core/native/src/internal/ThreadLocal.kt +++ b/kotlinx-coroutines-core/native/src/internal/ThreadLocal.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlin.native.concurrent.ThreadLocal diff --git a/kotlinx-coroutines-core/native/test/ConcurrentTestUtilities.kt b/kotlinx-coroutines-core/native/test/ConcurrentTestUtilities.kt index b8361b30ca..ff1638fd9a 100644 --- a/kotlinx-coroutines-core/native/test/ConcurrentTestUtilities.kt +++ b/kotlinx-coroutines-core/native/test/ConcurrentTestUtilities.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.exceptions import platform.posix.* diff --git a/kotlinx-coroutines-core/native/test/DelayExceptionTest.kt b/kotlinx-coroutines-core/native/test/DelayExceptionTest.kt index b0409935da..e80398c13d 100644 --- a/kotlinx-coroutines-core/native/test/DelayExceptionTest.kt +++ b/kotlinx-coroutines-core/native/test/DelayExceptionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/native/test/MultithreadedDispatchersTest.kt b/kotlinx-coroutines-core/native/test/MultithreadedDispatchersTest.kt index 501b7b5b4b..beaace279c 100644 --- a/kotlinx-coroutines-core/native/test/MultithreadedDispatchersTest.kt +++ b/kotlinx-coroutines-core/native/test/MultithreadedDispatchersTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/native/test/TestBase.kt b/kotlinx-coroutines-core/native/test/TestBase.kt index ca876969f5..12990bcd5c 100644 --- a/kotlinx-coroutines-core/native/test/TestBase.kt +++ b/kotlinx-coroutines-core/native/test/TestBase.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-core/native/test/WorkerTest.kt b/kotlinx-coroutines-core/native/test/WorkerTest.kt index 7ae31b2656..41c6cec89e 100644 --- a/kotlinx-coroutines-core/native/test/WorkerTest.kt +++ b/kotlinx-coroutines-core/native/test/WorkerTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.channels.* diff --git a/kotlinx-coroutines-core/nativeDarwin/src/Dispatchers.kt b/kotlinx-coroutines-core/nativeDarwin/src/Dispatchers.kt index bab9c9094e..31e41731d4 100644 --- a/kotlinx-coroutines-core/nativeDarwin/src/Dispatchers.kt +++ b/kotlinx-coroutines-core/nativeDarwin/src/Dispatchers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:OptIn(BetaInteropApi::class) package kotlinx.coroutines diff --git a/kotlinx-coroutines-core/nativeDarwin/test/Launcher.kt b/kotlinx-coroutines-core/nativeDarwin/test/Launcher.kt index 186bed49b2..4f63946852 100644 --- a/kotlinx-coroutines-core/nativeDarwin/test/Launcher.kt +++ b/kotlinx-coroutines-core/nativeDarwin/test/Launcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import platform.CoreFoundation.* diff --git a/kotlinx-coroutines-core/nativeDarwin/test/MainDispatcherTest.kt b/kotlinx-coroutines-core/nativeDarwin/test/MainDispatcherTest.kt index ba5c29cec2..ac967f4487 100644 --- a/kotlinx-coroutines-core/nativeDarwin/test/MainDispatcherTest.kt +++ b/kotlinx-coroutines-core/nativeDarwin/test/MainDispatcherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.cinterop.* diff --git a/kotlinx-coroutines-core/nativeOther/src/Dispatchers.kt b/kotlinx-coroutines-core/nativeOther/src/Dispatchers.kt index 17278b0be7..5d200d328a 100644 --- a/kotlinx-coroutines-core/nativeOther/src/Dispatchers.kt +++ b/kotlinx-coroutines-core/nativeOther/src/Dispatchers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/nativeOther/test/Launcher.kt b/kotlinx-coroutines-core/nativeOther/test/Launcher.kt index 07b51417b0..a957a5112a 100644 --- a/kotlinx-coroutines-core/nativeOther/test/Launcher.kt +++ b/kotlinx-coroutines-core/nativeOther/test/Launcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.native.concurrent.* diff --git a/kotlinx-coroutines-core/wasmJs/src/CompletionHandler.kt b/kotlinx-coroutines-core/wasmJs/src/CompletionHandler.kt index 4835f7968e..4737112e4f 100644 --- a/kotlinx-coroutines-core/wasmJs/src/CompletionHandler.kt +++ b/kotlinx-coroutines-core/wasmJs/src/CompletionHandler.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/wasmJs/src/CoroutineContext.kt b/kotlinx-coroutines-core/wasmJs/src/CoroutineContext.kt index ab37ff88d3..f4db72a687 100644 --- a/kotlinx-coroutines-core/wasmJs/src/CoroutineContext.kt +++ b/kotlinx-coroutines-core/wasmJs/src/CoroutineContext.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlinx.coroutines.internal.* diff --git a/kotlinx-coroutines-core/wasmJs/src/Debug.kt b/kotlinx-coroutines-core/wasmJs/src/Debug.kt index 93e253039f..00fa5bdbce 100644 --- a/kotlinx-coroutines-core/wasmJs/src/Debug.kt +++ b/kotlinx-coroutines-core/wasmJs/src/Debug.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines internal actual val DEBUG: Boolean = false diff --git a/kotlinx-coroutines-core/wasmJs/src/JSDispatcher.kt b/kotlinx-coroutines-core/wasmJs/src/JSDispatcher.kt index 3dfdeff321..9481e2f3e3 100644 --- a/kotlinx-coroutines-core/wasmJs/src/JSDispatcher.kt +++ b/kotlinx-coroutines-core/wasmJs/src/JSDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import org.w3c.dom.Window diff --git a/kotlinx-coroutines-core/wasmJs/src/Promise.kt b/kotlinx-coroutines-core/wasmJs/src/Promise.kt index f20bee3320..980f13867f 100644 --- a/kotlinx-coroutines-core/wasmJs/src/Promise.kt +++ b/kotlinx-coroutines-core/wasmJs/src/Promise.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.coroutines.* diff --git a/kotlinx-coroutines-core/wasmJs/src/internal/CopyOnWriteList.kt b/kotlinx-coroutines-core/wasmJs/src/internal/CopyOnWriteList.kt index 5d6f79fbcd..43496a5c10 100644 --- a/kotlinx-coroutines-core/wasmJs/src/internal/CopyOnWriteList.kt +++ b/kotlinx-coroutines-core/wasmJs/src/internal/CopyOnWriteList.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal @Suppress("UNCHECKED_CAST") diff --git a/kotlinx-coroutines-core/wasmJs/src/internal/CoroutineExceptionHandlerImpl.kt b/kotlinx-coroutines-core/wasmJs/src/internal/CoroutineExceptionHandlerImpl.kt index 097f4bb607..b3c09e7c38 100644 --- a/kotlinx-coroutines-core/wasmJs/src/internal/CoroutineExceptionHandlerImpl.kt +++ b/kotlinx-coroutines-core/wasmJs/src/internal/CoroutineExceptionHandlerImpl.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-core/wasmJs/test/PromiseTest.kt b/kotlinx-coroutines-core/wasmJs/test/PromiseTest.kt index 214f8294cd..4ae42c5c01 100644 --- a/kotlinx-coroutines-core/wasmJs/test/PromiseTest.kt +++ b/kotlinx-coroutines-core/wasmJs/test/PromiseTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.js.* diff --git a/kotlinx-coroutines-core/wasmJs/test/TestBase.kt b/kotlinx-coroutines-core/wasmJs/test/TestBase.kt index 08aedb7414..e5a326e629 100644 --- a/kotlinx-coroutines-core/wasmJs/test/TestBase.kt +++ b/kotlinx-coroutines-core/wasmJs/test/TestBase.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines import kotlin.js.* diff --git a/kotlinx-coroutines-debug/build.gradle.kts b/kotlinx-coroutines-debug/build.gradle.kts index d5fbf51541..83fc944fb9 100644 --- a/kotlinx-coroutines-debug/build.gradle.kts +++ b/kotlinx-coroutines-debug/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import com.github.jengelman.gradle.plugins.shadow.tasks.* import java.net.* import java.nio.file.* diff --git a/kotlinx-coroutines-debug/src/CoroutineInfo.kt b/kotlinx-coroutines-debug/src/CoroutineInfo.kt index 62728adab9..cb89405a30 100644 --- a/kotlinx-coroutines-debug/src/CoroutineInfo.kt +++ b/kotlinx-coroutines-debug/src/CoroutineInfo.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("INVISIBLE_MEMBER", "INVISIBLE_REFERENCE", "UNUSED") package kotlinx.coroutines.debug diff --git a/kotlinx-coroutines-debug/src/CoroutinesBlockHoundIntegration.kt b/kotlinx-coroutines-debug/src/CoroutinesBlockHoundIntegration.kt index 99f2b190ba..f8213eae22 100644 --- a/kotlinx-coroutines-debug/src/CoroutinesBlockHoundIntegration.kt +++ b/kotlinx-coroutines-debug/src/CoroutinesBlockHoundIntegration.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("INVISIBLE_REFERENCE", "INVISIBLE_MEMBER") package kotlinx.coroutines.debug diff --git a/kotlinx-coroutines-debug/src/DebugProbes.kt b/kotlinx-coroutines-debug/src/DebugProbes.kt index 0755f48943..a7f63ba348 100644 --- a/kotlinx-coroutines-debug/src/DebugProbes.kt +++ b/kotlinx-coroutines-debug/src/DebugProbes.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("UNUSED", "INVISIBLE_MEMBER", "INVISIBLE_REFERENCE") package kotlinx.coroutines.debug diff --git a/kotlinx-coroutines-debug/src/internal/Attach.kt b/kotlinx-coroutines-debug/src/internal/Attach.kt index f1cc96e6d3..63bfe8eafe 100644 --- a/kotlinx-coroutines-debug/src/internal/Attach.kt +++ b/kotlinx-coroutines-debug/src/internal/Attach.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("unused") package kotlinx.coroutines.debug.internal diff --git a/kotlinx-coroutines-debug/src/internal/NoOpProbes.kt b/kotlinx-coroutines-debug/src/internal/NoOpProbes.kt index 34f1afec65..b7b8bf50d4 100644 --- a/kotlinx-coroutines-debug/src/internal/NoOpProbes.kt +++ b/kotlinx-coroutines-debug/src/internal/NoOpProbes.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("unused", "UNUSED_PARAMETER") package kotlinx.coroutines.debug.internal diff --git a/kotlinx-coroutines-debug/src/junit/CoroutinesTimeoutImpl.kt b/kotlinx-coroutines-debug/src/junit/CoroutinesTimeoutImpl.kt index 06a84a5bf9..ba5804d5bb 100644 --- a/kotlinx-coroutines-debug/src/junit/CoroutinesTimeoutImpl.kt +++ b/kotlinx-coroutines-debug/src/junit/CoroutinesTimeoutImpl.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug import java.util.concurrent.* diff --git a/kotlinx-coroutines-debug/src/junit/junit4/CoroutinesTimeout.kt b/kotlinx-coroutines-debug/src/junit/junit4/CoroutinesTimeout.kt index 12bc947586..3a909991e6 100644 --- a/kotlinx-coroutines-debug/src/junit/junit4/CoroutinesTimeout.kt +++ b/kotlinx-coroutines-debug/src/junit/junit4/CoroutinesTimeout.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit4 import kotlinx.coroutines.debug.* diff --git a/kotlinx-coroutines-debug/src/junit/junit4/CoroutinesTimeoutStatement.kt b/kotlinx-coroutines-debug/src/junit/junit4/CoroutinesTimeoutStatement.kt index aa6b8df243..a51ea6aeee 100644 --- a/kotlinx-coroutines-debug/src/junit/junit4/CoroutinesTimeoutStatement.kt +++ b/kotlinx-coroutines-debug/src/junit/junit4/CoroutinesTimeoutStatement.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit4 import kotlinx.coroutines.debug.* diff --git a/kotlinx-coroutines-debug/src/junit/junit5/CoroutinesTimeout.kt b/kotlinx-coroutines-debug/src/junit/junit5/CoroutinesTimeout.kt index 9a8263fe5e..c2ac0599a5 100644 --- a/kotlinx-coroutines-debug/src/junit/junit5/CoroutinesTimeout.kt +++ b/kotlinx-coroutines-debug/src/junit/junit5/CoroutinesTimeout.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit5 import kotlinx.coroutines.debug.* import org.junit.jupiter.api.* diff --git a/kotlinx-coroutines-debug/src/junit/junit5/CoroutinesTimeoutExtension.kt b/kotlinx-coroutines-debug/src/junit/junit5/CoroutinesTimeoutExtension.kt index 442fdf8cdb..90e015b0dd 100644 --- a/kotlinx-coroutines-debug/src/junit/junit5/CoroutinesTimeoutExtension.kt +++ b/kotlinx-coroutines-debug/src/junit/junit5/CoroutinesTimeoutExtension.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit5 import kotlinx.coroutines.debug.* diff --git a/kotlinx-coroutines-debug/test/CoroutinesDumpTest.kt b/kotlinx-coroutines-debug/test/CoroutinesDumpTest.kt index 12573cf835..350d9dafbc 100644 --- a/kotlinx-coroutines-debug/test/CoroutinesDumpTest.kt +++ b/kotlinx-coroutines-debug/test/CoroutinesDumpTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/DebugLeaksTest.kt b/kotlinx-coroutines-debug/test/DebugLeaksTest.kt index a43b33be67..fecd41da12 100644 --- a/kotlinx-coroutines-debug/test/DebugLeaksTest.kt +++ b/kotlinx-coroutines-debug/test/DebugLeaksTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import kotlinx.coroutines.* import kotlinx.coroutines.debug.* import kotlinx.coroutines.debug.internal.* diff --git a/kotlinx-coroutines-debug/test/DebugProbesTest.kt b/kotlinx-coroutines-debug/test/DebugProbesTest.kt index cbeeb31171..4bdcb41057 100644 --- a/kotlinx-coroutines-debug/test/DebugProbesTest.kt +++ b/kotlinx-coroutines-debug/test/DebugProbesTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.debug import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/DebugTestBase.kt b/kotlinx-coroutines-debug/test/DebugTestBase.kt index 2a37f5883c..55b917609a 100644 --- a/kotlinx-coroutines-debug/test/DebugTestBase.kt +++ b/kotlinx-coroutines-debug/test/DebugTestBase.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.debug diff --git a/kotlinx-coroutines-debug/test/DumpCoroutineInfoAsJsonAndReferencesTest.kt b/kotlinx-coroutines-debug/test/DumpCoroutineInfoAsJsonAndReferencesTest.kt index 7d2521960f..ba18977d2f 100644 --- a/kotlinx-coroutines-debug/test/DumpCoroutineInfoAsJsonAndReferencesTest.kt +++ b/kotlinx-coroutines-debug/test/DumpCoroutineInfoAsJsonAndReferencesTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("INVISIBLE_MEMBER", "INVISIBLE_REFERENCE") package kotlinx.coroutines.debug diff --git a/kotlinx-coroutines-debug/test/DumpWithoutCreationStackTraceTest.kt b/kotlinx-coroutines-debug/test/DumpWithoutCreationStackTraceTest.kt index 6e405ca293..601a180d55 100644 --- a/kotlinx-coroutines-debug/test/DumpWithoutCreationStackTraceTest.kt +++ b/kotlinx-coroutines-debug/test/DumpWithoutCreationStackTraceTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.debug import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/EnhanceStackTraceWithTreadDumpAsJsonTest.kt b/kotlinx-coroutines-debug/test/EnhanceStackTraceWithTreadDumpAsJsonTest.kt index fcf9f1a9a9..a8cc0ee16c 100644 --- a/kotlinx-coroutines-debug/test/EnhanceStackTraceWithTreadDumpAsJsonTest.kt +++ b/kotlinx-coroutines-debug/test/EnhanceStackTraceWithTreadDumpAsJsonTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("INVISIBLE_MEMBER", "INVISIBLE_REFERENCE") package kotlinx.coroutines.debug diff --git a/kotlinx-coroutines-debug/test/LazyCoroutineTest.kt b/kotlinx-coroutines-debug/test/LazyCoroutineTest.kt index c872b6a53d..bc41912bd9 100644 --- a/kotlinx-coroutines-debug/test/LazyCoroutineTest.kt +++ b/kotlinx-coroutines-debug/test/LazyCoroutineTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.debug import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/RecoveryExample.kt b/kotlinx-coroutines-debug/test/RecoveryExample.kt index 2280dd1694..eeadcf5618 100644 --- a/kotlinx-coroutines-debug/test/RecoveryExample.kt +++ b/kotlinx-coroutines-debug/test/RecoveryExample.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("PackageDirectoryMismatch") package example diff --git a/kotlinx-coroutines-debug/test/RunningThreadStackMergeTest.kt b/kotlinx-coroutines-debug/test/RunningThreadStackMergeTest.kt index 89dd914879..175b93a9a8 100644 --- a/kotlinx-coroutines-debug/test/RunningThreadStackMergeTest.kt +++ b/kotlinx-coroutines-debug/test/RunningThreadStackMergeTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.debug import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/SanitizedProbesTest.kt b/kotlinx-coroutines-debug/test/SanitizedProbesTest.kt index 6afda16889..745e6d98eb 100644 --- a/kotlinx-coroutines-debug/test/SanitizedProbesTest.kt +++ b/kotlinx-coroutines-debug/test/SanitizedProbesTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("PackageDirectoryMismatch") package definitely.not.kotlinx.coroutines diff --git a/kotlinx-coroutines-debug/test/ScopedBuildersTest.kt b/kotlinx-coroutines-debug/test/ScopedBuildersTest.kt index 801b74b1aa..3707c08474 100644 --- a/kotlinx-coroutines-debug/test/ScopedBuildersTest.kt +++ b/kotlinx-coroutines-debug/test/ScopedBuildersTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/StacktraceUtils.kt b/kotlinx-coroutines-debug/test/StacktraceUtils.kt index 869e29751c..90ce38907e 100644 --- a/kotlinx-coroutines-debug/test/StacktraceUtils.kt +++ b/kotlinx-coroutines-debug/test/StacktraceUtils.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug import java.io.* diff --git a/kotlinx-coroutines-debug/test/StandardBuildersDebugTest.kt b/kotlinx-coroutines-debug/test/StandardBuildersDebugTest.kt index 7ca8f142eb..a9b4c90357 100644 --- a/kotlinx-coroutines-debug/test/StandardBuildersDebugTest.kt +++ b/kotlinx-coroutines-debug/test/StandardBuildersDebugTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.debug import org.junit.Test diff --git a/kotlinx-coroutines-debug/test/StartModeProbesTest.kt b/kotlinx-coroutines-debug/test/StartModeProbesTest.kt index c2656d346b..2526da88a8 100644 --- a/kotlinx-coroutines-debug/test/StartModeProbesTest.kt +++ b/kotlinx-coroutines-debug/test/StartModeProbesTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/TestRuleExample.kt b/kotlinx-coroutines-debug/test/TestRuleExample.kt index b5d1c262bf..df5473e084 100644 --- a/kotlinx-coroutines-debug/test/TestRuleExample.kt +++ b/kotlinx-coroutines-debug/test/TestRuleExample.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import kotlinx.coroutines.* import kotlinx.coroutines.debug.junit4.* import org.junit.* diff --git a/kotlinx-coroutines-debug/test/ToStringTest.kt b/kotlinx-coroutines-debug/test/ToStringTest.kt index 0ea412b55d..b336930c09 100644 --- a/kotlinx-coroutines-debug/test/ToStringTest.kt +++ b/kotlinx-coroutines-debug/test/ToStringTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/WithContextUndispatchedTest.kt b/kotlinx-coroutines-debug/test/WithContextUndispatchedTest.kt index e803c980cf..bf0c5ca55b 100644 --- a/kotlinx-coroutines-debug/test/WithContextUndispatchedTest.kt +++ b/kotlinx-coroutines-debug/test/WithContextUndispatchedTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.debug import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutDisabledTracesTest.kt b/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutDisabledTracesTest.kt index 4352140bd7..4e02bc5da5 100644 --- a/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutDisabledTracesTest.kt +++ b/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutDisabledTracesTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit4 import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutEagerTest.kt b/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutEagerTest.kt index 7a686ff2a7..b02f8a2ce3 100644 --- a/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutEagerTest.kt +++ b/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutEagerTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit4 import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutTest.kt b/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutTest.kt index 53447ac5f9..3d5a4cc7ee 100644 --- a/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutTest.kt +++ b/kotlinx-coroutines-debug/test/junit4/CoroutinesTimeoutTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit4 import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/junit4/TestFailureValidation.kt b/kotlinx-coroutines-debug/test/junit4/TestFailureValidation.kt index 6d25a6da7d..5bbb84c788 100644 --- a/kotlinx-coroutines-debug/test/junit4/TestFailureValidation.kt +++ b/kotlinx-coroutines-debug/test/junit4/TestFailureValidation.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit4 import kotlinx.coroutines.debug.* diff --git a/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutExtensionTest.kt b/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutExtensionTest.kt index 752c6c35cd..12298152ce 100644 --- a/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutExtensionTest.kt +++ b/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutExtensionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit5 import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutInheritanceTest.kt b/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutInheritanceTest.kt index 7c8de53db7..1e03d19308 100644 --- a/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutInheritanceTest.kt +++ b/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutInheritanceTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit5 import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutMethodTest.kt b/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutMethodTest.kt index 64611b31e4..02bcafcd6b 100644 --- a/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutMethodTest.kt +++ b/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutMethodTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit5 import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutNestedTest.kt b/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutNestedTest.kt index 04c933d043..afb51698ed 100644 --- a/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutNestedTest.kt +++ b/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutNestedTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit5 import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutSimpleTest.kt b/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutSimpleTest.kt index 513a884601..01487b76a2 100644 --- a/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutSimpleTest.kt +++ b/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutSimpleTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit5 import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutTest.kt b/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutTest.kt index 1f7b2080cb..e504a3c315 100644 --- a/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutTest.kt +++ b/kotlinx-coroutines-debug/test/junit5/CoroutinesTimeoutTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit5 import org.assertj.core.api.* diff --git a/kotlinx-coroutines-debug/test/junit5/RegisterExtensionExample.kt b/kotlinx-coroutines-debug/test/junit5/RegisterExtensionExample.kt index 2de6b5b289..10411b7144 100644 --- a/kotlinx-coroutines-debug/test/junit5/RegisterExtensionExample.kt +++ b/kotlinx-coroutines-debug/test/junit5/RegisterExtensionExample.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.debug.junit5 import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/build.gradle.kts b/kotlinx-coroutines-test/build.gradle.kts index 1e317c5900..aa98ce8ffa 100644 --- a/kotlinx-coroutines-test/build.gradle.kts +++ b/kotlinx-coroutines-test/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.jetbrains.kotlin.gradle.plugin.mpp.* val experimentalAnnotations = listOf( diff --git a/kotlinx-coroutines-test/common/src/TestBuilders.kt b/kotlinx-coroutines-test/common/src/TestBuilders.kt index 26952efa6d..1a763b6dc2 100644 --- a/kotlinx-coroutines-test/common/src/TestBuilders.kt +++ b/kotlinx-coroutines-test/common/src/TestBuilders.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:JvmName("TestBuildersKt") @file:JvmMultifileClass diff --git a/kotlinx-coroutines-test/common/src/TestCoroutineDispatchers.kt b/kotlinx-coroutines-test/common/src/TestCoroutineDispatchers.kt index d380bb4bd2..1b85bf9ec5 100644 --- a/kotlinx-coroutines-test/common/src/TestCoroutineDispatchers.kt +++ b/kotlinx-coroutines-test/common/src/TestCoroutineDispatchers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/common/src/TestCoroutineScheduler.kt b/kotlinx-coroutines-test/common/src/TestCoroutineScheduler.kt index 04e320d841..a4d3ee51c5 100644 --- a/kotlinx-coroutines-test/common/src/TestCoroutineScheduler.kt +++ b/kotlinx-coroutines-test/common/src/TestCoroutineScheduler.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-test/common/src/TestDispatcher.kt b/kotlinx-coroutines-test/common/src/TestDispatcher.kt index b027131c82..3e8803bf01 100644 --- a/kotlinx-coroutines-test/common/src/TestDispatcher.kt +++ b/kotlinx-coroutines-test/common/src/TestDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/common/src/TestDispatchers.kt b/kotlinx-coroutines-test/common/src/TestDispatchers.kt index 4454597ed7..a9e4524507 100644 --- a/kotlinx-coroutines-test/common/src/TestDispatchers.kt +++ b/kotlinx-coroutines-test/common/src/TestDispatchers.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:JvmName("TestDispatchers") package kotlinx.coroutines.test diff --git a/kotlinx-coroutines-test/common/src/TestScope.kt b/kotlinx-coroutines-test/common/src/TestScope.kt index 7089255669..9ecea83c0c 100644 --- a/kotlinx-coroutines-test/common/src/TestScope.kt +++ b/kotlinx-coroutines-test/common/src/TestScope.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/common/src/internal/ExceptionCollector.kt b/kotlinx-coroutines-test/common/src/internal/ExceptionCollector.kt index 6387e791bd..67341ddaf9 100644 --- a/kotlinx-coroutines-test/common/src/internal/ExceptionCollector.kt +++ b/kotlinx-coroutines-test/common/src/internal/ExceptionCollector.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/common/src/internal/ReportingSupervisorJob.kt b/kotlinx-coroutines-test/common/src/internal/ReportingSupervisorJob.kt index e3091bc263..3752f4e26d 100644 --- a/kotlinx-coroutines-test/common/src/internal/ReportingSupervisorJob.kt +++ b/kotlinx-coroutines-test/common/src/internal/ReportingSupervisorJob.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/common/src/internal/TestMainDispatcher.kt b/kotlinx-coroutines-test/common/src/internal/TestMainDispatcher.kt index acb45e0899..b94e261f7b 100644 --- a/kotlinx-coroutines-test/common/src/internal/TestMainDispatcher.kt +++ b/kotlinx-coroutines-test/common/src/internal/TestMainDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test.internal import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-test/common/test/Helpers.kt b/kotlinx-coroutines-test/common/test/Helpers.kt index db60c5ddf6..8d8b91df6a 100644 --- a/kotlinx-coroutines-test/common/test/Helpers.kt +++ b/kotlinx-coroutines-test/common/test/Helpers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-test/common/test/RunTestTest.kt b/kotlinx-coroutines-test/common/test/RunTestTest.kt index 6f31cca349..ca3114c618 100644 --- a/kotlinx-coroutines-test/common/test/RunTestTest.kt +++ b/kotlinx-coroutines-test/common/test/RunTestTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/common/test/StandardTestDispatcherTest.kt b/kotlinx-coroutines-test/common/test/StandardTestDispatcherTest.kt index 280d668588..3001f2bcf3 100644 --- a/kotlinx-coroutines-test/common/test/StandardTestDispatcherTest.kt +++ b/kotlinx-coroutines-test/common/test/StandardTestDispatcherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/common/test/TestCoroutineSchedulerTest.kt b/kotlinx-coroutines-test/common/test/TestCoroutineSchedulerTest.kt index 4aec77312d..e0f8c00e3f 100644 --- a/kotlinx-coroutines-test/common/test/TestCoroutineSchedulerTest.kt +++ b/kotlinx-coroutines-test/common/test/TestCoroutineSchedulerTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/common/test/TestDispatchersTest.kt b/kotlinx-coroutines-test/common/test/TestDispatchersTest.kt index da48e7f47a..f442814cd9 100644 --- a/kotlinx-coroutines-test/common/test/TestDispatchersTest.kt +++ b/kotlinx-coroutines-test/common/test/TestDispatchersTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/common/test/TestScopeTest.kt b/kotlinx-coroutines-test/common/test/TestScopeTest.kt index 76791365fc..8dde491a50 100644 --- a/kotlinx-coroutines-test/common/test/TestScopeTest.kt +++ b/kotlinx-coroutines-test/common/test/TestScopeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/common/test/UnconfinedTestDispatcherTest.kt b/kotlinx-coroutines-test/common/test/UnconfinedTestDispatcherTest.kt index 23ff0ac16b..ddcdc4a548 100644 --- a/kotlinx-coroutines-test/common/test/UnconfinedTestDispatcherTest.kt +++ b/kotlinx-coroutines-test/common/test/UnconfinedTestDispatcherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/js/src/TestBuilders.kt b/kotlinx-coroutines-test/js/src/TestBuilders.kt index f1148135d9..8d30201c3f 100644 --- a/kotlinx-coroutines-test/js/src/TestBuilders.kt +++ b/kotlinx-coroutines-test/js/src/TestBuilders.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* import kotlin.js.* diff --git a/kotlinx-coroutines-test/js/src/internal/TestMainDispatcher.kt b/kotlinx-coroutines-test/js/src/internal/TestMainDispatcher.kt index d68cecda70..5fca8947c7 100644 --- a/kotlinx-coroutines-test/js/src/internal/TestMainDispatcher.kt +++ b/kotlinx-coroutines-test/js/src/internal/TestMainDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/js/test/Helpers.kt b/kotlinx-coroutines-test/js/test/Helpers.kt index 5fd0291c3b..b230c2b342 100644 --- a/kotlinx-coroutines-test/js/test/Helpers.kt +++ b/kotlinx-coroutines-test/js/test/Helpers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlin.test.* diff --git a/kotlinx-coroutines-test/js/test/PromiseTest.kt b/kotlinx-coroutines-test/js/test/PromiseTest.kt index ff09d9ab86..8774e4aba4 100644 --- a/kotlinx-coroutines-test/js/test/PromiseTest.kt +++ b/kotlinx-coroutines-test/js/test/PromiseTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/jvm/src/TestBuildersJvm.kt b/kotlinx-coroutines-test/jvm/src/TestBuildersJvm.kt index 1307e036ba..dc7e0988bd 100644 --- a/kotlinx-coroutines-test/jvm/src/TestBuildersJvm.kt +++ b/kotlinx-coroutines-test/jvm/src/TestBuildersJvm.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/jvm/src/internal/TestMainDispatcherJvm.kt b/kotlinx-coroutines-test/jvm/src/internal/TestMainDispatcherJvm.kt index f86b08ea14..1b2d7533de 100644 --- a/kotlinx-coroutines-test/jvm/src/internal/TestMainDispatcherJvm.kt +++ b/kotlinx-coroutines-test/jvm/src/internal/TestMainDispatcherJvm.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/jvm/src/migration/DelayController.kt b/kotlinx-coroutines-test/jvm/src/migration/DelayController.kt index ab84da1c0e..f1aa213872 100644 --- a/kotlinx-coroutines-test/jvm/src/migration/DelayController.kt +++ b/kotlinx-coroutines-test/jvm/src/migration/DelayController.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("DEPRECATION_ERROR") package kotlinx.coroutines.test diff --git a/kotlinx-coroutines-test/jvm/src/migration/TestBuildersDeprecated.kt b/kotlinx-coroutines-test/jvm/src/migration/TestBuildersDeprecated.kt index 7a98fd1ddc..2e0155bfcd 100644 --- a/kotlinx-coroutines-test/jvm/src/migration/TestBuildersDeprecated.kt +++ b/kotlinx-coroutines-test/jvm/src/migration/TestBuildersDeprecated.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("DEPRECATION") @file:JvmName("TestBuildersKt") @file:JvmMultifileClass diff --git a/kotlinx-coroutines-test/jvm/src/migration/TestCoroutineDispatcher.kt b/kotlinx-coroutines-test/jvm/src/migration/TestCoroutineDispatcher.kt index 3f049b6fda..1c72a2fdd9 100644 --- a/kotlinx-coroutines-test/jvm/src/migration/TestCoroutineDispatcher.kt +++ b/kotlinx-coroutines-test/jvm/src/migration/TestCoroutineDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/jvm/src/migration/TestCoroutineExceptionHandler.kt b/kotlinx-coroutines-test/jvm/src/migration/TestCoroutineExceptionHandler.kt index 24f2166eb3..eeff64d2e9 100644 --- a/kotlinx-coroutines-test/jvm/src/migration/TestCoroutineExceptionHandler.kt +++ b/kotlinx-coroutines-test/jvm/src/migration/TestCoroutineExceptionHandler.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/jvm/src/migration/TestCoroutineScope.kt b/kotlinx-coroutines-test/jvm/src/migration/TestCoroutineScope.kt index 4a503c5eb2..f172ab638e 100644 --- a/kotlinx-coroutines-test/jvm/src/migration/TestCoroutineScope.kt +++ b/kotlinx-coroutines-test/jvm/src/migration/TestCoroutineScope.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("DEPRECATION_ERROR", "DEPRECATION") package kotlinx.coroutines.test diff --git a/kotlinx-coroutines-test/jvm/test/DumpOnTimeoutTest.kt b/kotlinx-coroutines-test/jvm/test/DumpOnTimeoutTest.kt index 814e5f0667..36f73c2d39 100644 --- a/kotlinx-coroutines-test/jvm/test/DumpOnTimeoutTest.kt +++ b/kotlinx-coroutines-test/jvm/test/DumpOnTimeoutTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/jvm/test/HelpersJvm.kt b/kotlinx-coroutines-test/jvm/test/HelpersJvm.kt index 8d40b078a3..ed3afa39e4 100644 --- a/kotlinx-coroutines-test/jvm/test/HelpersJvm.kt +++ b/kotlinx-coroutines-test/jvm/test/HelpersJvm.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.test actual fun testResultChain(block: () -> TestResult, after: (Result) -> TestResult): TestResult { diff --git a/kotlinx-coroutines-test/jvm/test/MemoryLeakTest.kt b/kotlinx-coroutines-test/jvm/test/MemoryLeakTest.kt index 705c97eae4..fb0c062cf4 100644 --- a/kotlinx-coroutines-test/jvm/test/MemoryLeakTest.kt +++ b/kotlinx-coroutines-test/jvm/test/MemoryLeakTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ import kotlinx.coroutines.* import kotlinx.coroutines.test.* import kotlin.test.* diff --git a/kotlinx-coroutines-test/jvm/test/MultithreadingTest.kt b/kotlinx-coroutines-test/jvm/test/MultithreadingTest.kt index 2ac577c41b..4761769bbd 100644 --- a/kotlinx-coroutines-test/jvm/test/MultithreadingTest.kt +++ b/kotlinx-coroutines-test/jvm/test/MultithreadingTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import kotlinx.coroutines.* import kotlinx.coroutines.test.* import kotlin.concurrent.* diff --git a/kotlinx-coroutines-test/jvm/test/RunTestStressTest.kt b/kotlinx-coroutines-test/jvm/test/RunTestStressTest.kt index 3edaa48fbd..7bd9b0e068 100644 --- a/kotlinx-coroutines-test/jvm/test/RunTestStressTest.kt +++ b/kotlinx-coroutines-test/jvm/test/RunTestStressTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/jvm/test/UncaughtExceptionsTest.kt b/kotlinx-coroutines-test/jvm/test/UncaughtExceptionsTest.kt index d3802eda14..9f0f657a8d 100644 --- a/kotlinx-coroutines-test/jvm/test/UncaughtExceptionsTest.kt +++ b/kotlinx-coroutines-test/jvm/test/UncaughtExceptionsTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2023 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.test import org.junit.Test diff --git a/kotlinx-coroutines-test/jvm/test/migration/RunBlockingTestOnTestScopeTest.kt b/kotlinx-coroutines-test/jvm/test/migration/RunBlockingTestOnTestScopeTest.kt index 806592079c..fe9be521ec 100644 --- a/kotlinx-coroutines-test/jvm/test/migration/RunBlockingTestOnTestScopeTest.kt +++ b/kotlinx-coroutines-test/jvm/test/migration/RunBlockingTestOnTestScopeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/jvm/test/migration/RunTestLegacyScopeTest.kt b/kotlinx-coroutines-test/jvm/test/migration/RunTestLegacyScopeTest.kt index 4f05c1920f..9d35691363 100644 --- a/kotlinx-coroutines-test/jvm/test/migration/RunTestLegacyScopeTest.kt +++ b/kotlinx-coroutines-test/jvm/test/migration/RunTestLegacyScopeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/jvm/test/migration/TestBuildersTest.kt b/kotlinx-coroutines-test/jvm/test/migration/TestBuildersTest.kt index 4b0428d0fe..d03fc9cfc1 100644 --- a/kotlinx-coroutines-test/jvm/test/migration/TestBuildersTest.kt +++ b/kotlinx-coroutines-test/jvm/test/migration/TestBuildersTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineDispatcherOrderTest.kt b/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineDispatcherOrderTest.kt index 115c2729da..03470f30b6 100644 --- a/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineDispatcherOrderTest.kt +++ b/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineDispatcherOrderTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.atomicfu.* diff --git a/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineDispatcherTest.kt b/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineDispatcherTest.kt index ea9762ffd0..d5f3e0f576 100644 --- a/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineDispatcherTest.kt +++ b/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineDispatcherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineExceptionHandlerTest.kt b/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineExceptionHandlerTest.kt index 332634eafd..72fae5d69e 100644 --- a/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineExceptionHandlerTest.kt +++ b/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineExceptionHandlerTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlin.test.* diff --git a/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineScopeTest.kt b/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineScopeTest.kt index 1a62613790..b260c98a63 100644 --- a/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineScopeTest.kt +++ b/kotlinx-coroutines-test/jvm/test/migration/TestCoroutineScopeTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ @file:Suppress("DEPRECATION") package kotlinx.coroutines.test diff --git a/kotlinx-coroutines-test/jvm/test/migration/TestRunBlockingOrderTest.kt b/kotlinx-coroutines-test/jvm/test/migration/TestRunBlockingOrderTest.kt index 32514d90e8..95ef3eb8f9 100644 --- a/kotlinx-coroutines-test/jvm/test/migration/TestRunBlockingOrderTest.kt +++ b/kotlinx-coroutines-test/jvm/test/migration/TestRunBlockingOrderTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/jvm/test/migration/TestRunBlockingTest.kt b/kotlinx-coroutines-test/jvm/test/migration/TestRunBlockingTest.kt index ebdd973b5b..6633a7587f 100644 --- a/kotlinx-coroutines-test/jvm/test/migration/TestRunBlockingTest.kt +++ b/kotlinx-coroutines-test/jvm/test/migration/TestRunBlockingTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/native/src/TestBuilders.kt b/kotlinx-coroutines-test/native/src/TestBuilders.kt index 2714b45823..b1d838703a 100644 --- a/kotlinx-coroutines-test/native/src/TestBuilders.kt +++ b/kotlinx-coroutines-test/native/src/TestBuilders.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/native/src/internal/TestMainDispatcher.kt b/kotlinx-coroutines-test/native/src/internal/TestMainDispatcher.kt index d68cecda70..5fca8947c7 100644 --- a/kotlinx-coroutines-test/native/src/internal/TestMainDispatcher.kt +++ b/kotlinx-coroutines-test/native/src/internal/TestMainDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/native/test/Helpers.kt b/kotlinx-coroutines-test/native/test/Helpers.kt index be615fb022..19de989e5e 100644 --- a/kotlinx-coroutines-test/native/test/Helpers.kt +++ b/kotlinx-coroutines-test/native/test/Helpers.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.test import kotlin.test.* diff --git a/kotlinx-coroutines-test/wasmJs/src/TestBuilders.kt b/kotlinx-coroutines-test/wasmJs/src/TestBuilders.kt index 898750b8bd..7794b8ec7f 100644 --- a/kotlinx-coroutines-test/wasmJs/src/TestBuilders.kt +++ b/kotlinx-coroutines-test/wasmJs/src/TestBuilders.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlinx.coroutines.* import kotlin.js.* diff --git a/kotlinx-coroutines-test/wasmJs/src/internal/TestMainDispatcher.kt b/kotlinx-coroutines-test/wasmJs/src/internal/TestMainDispatcher.kt index 4d865f83c0..175a84695a 100644 --- a/kotlinx-coroutines-test/wasmJs/src/internal/TestMainDispatcher.kt +++ b/kotlinx-coroutines-test/wasmJs/src/internal/TestMainDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test.internal import kotlinx.coroutines.* diff --git a/kotlinx-coroutines-test/wasmJs/test/Helpers.kt b/kotlinx-coroutines-test/wasmJs/test/Helpers.kt index 1a8d63d7a7..5c0250915e 100644 --- a/kotlinx-coroutines-test/wasmJs/test/Helpers.kt +++ b/kotlinx-coroutines-test/wasmJs/test/Helpers.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.test import kotlin.test.* diff --git a/kotlinx-coroutines-test/wasmJs/test/PromiseTest.kt b/kotlinx-coroutines-test/wasmJs/test/PromiseTest.kt index 087db81eb8..f55517154a 100644 --- a/kotlinx-coroutines-test/wasmJs/test/PromiseTest.kt +++ b/kotlinx-coroutines-test/wasmJs/test/PromiseTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.test import kotlinx.coroutines.* diff --git a/license/NOTICE.txt b/license/NOTICE.txt index 8d1100a3a5..01d81385e4 100644 --- a/license/NOTICE.txt +++ b/license/NOTICE.txt @@ -5,4 +5,4 @@ ========================================================================= kotlinx.coroutines library. -Copyright 2016-2021 JetBrains s.r.o and respective authors and developers +Copyright 2016-2024 JetBrains s.r.o and contributors diff --git a/reactive/knit.properties b/reactive/knit.properties index 452cd2f17b..1a28ea50f7 100644 --- a/reactive/knit.properties +++ b/reactive/knit.properties @@ -1,6 +1,2 @@ -# -# Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. -# - knit.package=kotlinx.coroutines.rx2.guide knit.dir=kotlinx-coroutines-rx2/test/guide/ diff --git a/reactive/knit.test.include b/reactive/knit.test.include index dd9e61d041..2de7062387 100644 --- a/reactive/knit.test.include +++ b/reactive/knit.test.include @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from ${file.name} by Knit tool. Do not edit. package ${test.package} diff --git a/reactive/kotlinx-coroutines-jdk9/build.gradle.kts b/reactive/kotlinx-coroutines-jdk9/build.gradle.kts index 9c5580ce35..381dda50b3 100644 --- a/reactive/kotlinx-coroutines-jdk9/build.gradle.kts +++ b/reactive/kotlinx-coroutines-jdk9/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.jetbrains.kotlin.gradle.dsl.* dependencies { diff --git a/reactive/kotlinx-coroutines-jdk9/src/Await.kt b/reactive/kotlinx-coroutines-jdk9/src/Await.kt index dfe6ec52f2..b33ba43f97 100644 --- a/reactive/kotlinx-coroutines-jdk9/src/Await.kt +++ b/reactive/kotlinx-coroutines-jdk9/src/Await.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.jdk9 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-jdk9/src/Publish.kt b/reactive/kotlinx-coroutines-jdk9/src/Publish.kt index 529bc12fdc..019e604888 100644 --- a/reactive/kotlinx-coroutines-jdk9/src/Publish.kt +++ b/reactive/kotlinx-coroutines-jdk9/src/Publish.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.jdk9 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-jdk9/src/ReactiveFlow.kt b/reactive/kotlinx-coroutines-jdk9/src/ReactiveFlow.kt index 6031e0a8ad..11f3a95fe1 100644 --- a/reactive/kotlinx-coroutines-jdk9/src/ReactiveFlow.kt +++ b/reactive/kotlinx-coroutines-jdk9/src/ReactiveFlow.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.jdk9 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-jdk9/test/AwaitTest.kt b/reactive/kotlinx-coroutines-jdk9/test/AwaitTest.kt index 5a95d098fd..8fb93ed534 100644 --- a/reactive/kotlinx-coroutines-jdk9/test/AwaitTest.kt +++ b/reactive/kotlinx-coroutines-jdk9/test/AwaitTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.jdk9 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-jdk9/test/FlowAsPublisherTest.kt b/reactive/kotlinx-coroutines-jdk9/test/FlowAsPublisherTest.kt index b860e16209..9e702fddaf 100644 --- a/reactive/kotlinx-coroutines-jdk9/test/FlowAsPublisherTest.kt +++ b/reactive/kotlinx-coroutines-jdk9/test/FlowAsPublisherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.jdk9 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-jdk9/test/IntegrationTest.kt b/reactive/kotlinx-coroutines-jdk9/test/IntegrationTest.kt index 5b3542ad89..81e3f10d35 100644 --- a/reactive/kotlinx-coroutines-jdk9/test/IntegrationTest.kt +++ b/reactive/kotlinx-coroutines-jdk9/test/IntegrationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.jdk9 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-jdk9/test/PublishTest.kt b/reactive/kotlinx-coroutines-jdk9/test/PublishTest.kt index 0479028d80..aa4f620628 100644 --- a/reactive/kotlinx-coroutines-jdk9/test/PublishTest.kt +++ b/reactive/kotlinx-coroutines-jdk9/test/PublishTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.jdk9 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-jdk9/test/PublisherAsFlowTest.kt b/reactive/kotlinx-coroutines-jdk9/test/PublisherAsFlowTest.kt index b5b2a0a2b8..12084acc3d 100644 --- a/reactive/kotlinx-coroutines-jdk9/test/PublisherAsFlowTest.kt +++ b/reactive/kotlinx-coroutines-jdk9/test/PublisherAsFlowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.jdk9 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-jdk9/test/PublisherBackpressureTest.kt b/reactive/kotlinx-coroutines-jdk9/test/PublisherBackpressureTest.kt index bc9d58ebcf..303c829816 100644 --- a/reactive/kotlinx-coroutines-jdk9/test/PublisherBackpressureTest.kt +++ b/reactive/kotlinx-coroutines-jdk9/test/PublisherBackpressureTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.jdk9 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-jdk9/test/PublisherCollectTest.kt b/reactive/kotlinx-coroutines-jdk9/test/PublisherCollectTest.kt index c2e88483a7..9288d7c5ea 100644 --- a/reactive/kotlinx-coroutines-jdk9/test/PublisherCollectTest.kt +++ b/reactive/kotlinx-coroutines-jdk9/test/PublisherCollectTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.jdk9 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-jdk9/test/PublisherCompletionStressTest.kt b/reactive/kotlinx-coroutines-jdk9/test/PublisherCompletionStressTest.kt index 8462df2c6f..b557020b1f 100644 --- a/reactive/kotlinx-coroutines-jdk9/test/PublisherCompletionStressTest.kt +++ b/reactive/kotlinx-coroutines-jdk9/test/PublisherCompletionStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.jdk9 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-jdk9/test/PublisherMultiTest.kt b/reactive/kotlinx-coroutines-jdk9/test/PublisherMultiTest.kt index a44850b52d..020f593d4e 100644 --- a/reactive/kotlinx-coroutines-jdk9/test/PublisherMultiTest.kt +++ b/reactive/kotlinx-coroutines-jdk9/test/PublisherMultiTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.jdk9 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/build.gradle.kts b/reactive/kotlinx-coroutines-reactive/build.gradle.kts index d54a409c00..f49ffa0100 100644 --- a/reactive/kotlinx-coroutines-reactive/build.gradle.kts +++ b/reactive/kotlinx-coroutines-reactive/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - plugins { // apply plugin to use autocomplete for Kover DSL id("org.jetbrains.kotlinx.kover") diff --git a/reactive/kotlinx-coroutines-reactive/src/Await.kt b/reactive/kotlinx-coroutines-reactive/src/Await.kt index 446d986cb6..8ba387d161 100644 --- a/reactive/kotlinx-coroutines-reactive/src/Await.kt +++ b/reactive/kotlinx-coroutines-reactive/src/Await.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/src/Channel.kt b/reactive/kotlinx-coroutines-reactive/src/Channel.kt index 7836ed7d0d..4b775f7272 100644 --- a/reactive/kotlinx-coroutines-reactive/src/Channel.kt +++ b/reactive/kotlinx-coroutines-reactive/src/Channel.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.atomicfu.* diff --git a/reactive/kotlinx-coroutines-reactive/src/ContextInjector.kt b/reactive/kotlinx-coroutines-reactive/src/ContextInjector.kt index 043e223d49..abf0946377 100644 --- a/reactive/kotlinx-coroutines-reactive/src/ContextInjector.kt +++ b/reactive/kotlinx-coroutines-reactive/src/ContextInjector.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.InternalCoroutinesApi diff --git a/reactive/kotlinx-coroutines-reactive/src/Convert.kt b/reactive/kotlinx-coroutines-reactive/src/Convert.kt index 9492b49871..55bce6c08a 100644 --- a/reactive/kotlinx-coroutines-reactive/src/Convert.kt +++ b/reactive/kotlinx-coroutines-reactive/src/Convert.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.channels.* diff --git a/reactive/kotlinx-coroutines-reactive/src/Migration.kt b/reactive/kotlinx-coroutines-reactive/src/Migration.kt index 858ab00e98..3fc94d5afd 100644 --- a/reactive/kotlinx-coroutines-reactive/src/Migration.kt +++ b/reactive/kotlinx-coroutines-reactive/src/Migration.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmMultifileClass @file:JvmName("FlowKt") diff --git a/reactive/kotlinx-coroutines-reactive/src/Publish.kt b/reactive/kotlinx-coroutines-reactive/src/Publish.kt index a516777860..a58e01f5d7 100644 --- a/reactive/kotlinx-coroutines-reactive/src/Publish.kt +++ b/reactive/kotlinx-coroutines-reactive/src/Publish.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package kotlinx.coroutines.reactive import kotlinx.atomicfu.* diff --git a/reactive/kotlinx-coroutines-reactive/src/ReactiveFlow.kt b/reactive/kotlinx-coroutines-reactive/src/ReactiveFlow.kt index 7e6dcefae2..79cc87aa1d 100644 --- a/reactive/kotlinx-coroutines-reactive/src/ReactiveFlow.kt +++ b/reactive/kotlinx-coroutines-reactive/src/ReactiveFlow.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.atomicfu.* diff --git a/reactive/kotlinx-coroutines-reactive/test/AwaitCancellationStressTest.kt b/reactive/kotlinx-coroutines-reactive/test/AwaitCancellationStressTest.kt index aaf8df6e69..50d570a0da 100644 --- a/reactive/kotlinx-coroutines-reactive/test/AwaitCancellationStressTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/AwaitCancellationStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/AwaitTest.kt b/reactive/kotlinx-coroutines-reactive/test/AwaitTest.kt index 6749423f80..3039dd7706 100644 --- a/reactive/kotlinx-coroutines-reactive/test/AwaitTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/AwaitTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/CancelledParentAttachTest.kt b/reactive/kotlinx-coroutines-reactive/test/CancelledParentAttachTest.kt index 1db10b278d..19db66735b 100644 --- a/reactive/kotlinx-coroutines-reactive/test/CancelledParentAttachTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/CancelledParentAttachTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/FlowAsPublisherTest.kt b/reactive/kotlinx-coroutines-reactive/test/FlowAsPublisherTest.kt index 02c9e242e9..2a393ba224 100644 --- a/reactive/kotlinx-coroutines-reactive/test/FlowAsPublisherTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/FlowAsPublisherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/IntegrationTest.kt b/reactive/kotlinx-coroutines-reactive/test/IntegrationTest.kt index fa039897d7..29bbd7d364 100644 --- a/reactive/kotlinx-coroutines-reactive/test/IntegrationTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/IntegrationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/IterableFlowTckTest.kt b/reactive/kotlinx-coroutines-reactive/test/IterableFlowTckTest.kt index cf935f97dc..13313d2909 100644 --- a/reactive/kotlinx-coroutines-reactive/test/IterableFlowTckTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/IterableFlowTckTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("UNCHECKED_CAST") package kotlinx.coroutines.reactive diff --git a/reactive/kotlinx-coroutines-reactive/test/PublishTest.kt b/reactive/kotlinx-coroutines-reactive/test/PublishTest.kt index d92a8883be..15e22aa223 100644 --- a/reactive/kotlinx-coroutines-reactive/test/PublishTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/PublishTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/PublisherAsFlowTest.kt b/reactive/kotlinx-coroutines-reactive/test/PublisherAsFlowTest.kt index 7a0e0fac38..04f955874a 100644 --- a/reactive/kotlinx-coroutines-reactive/test/PublisherAsFlowTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/PublisherAsFlowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/PublisherBackpressureTest.kt b/reactive/kotlinx-coroutines-reactive/test/PublisherBackpressureTest.kt index 258632bcfe..c69664a232 100644 --- a/reactive/kotlinx-coroutines-reactive/test/PublisherBackpressureTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/PublisherBackpressureTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/PublisherCollectTest.kt b/reactive/kotlinx-coroutines-reactive/test/PublisherCollectTest.kt index e4753f0467..841cd66141 100644 --- a/reactive/kotlinx-coroutines-reactive/test/PublisherCollectTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/PublisherCollectTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/PublisherCompletionStressTest.kt b/reactive/kotlinx-coroutines-reactive/test/PublisherCompletionStressTest.kt index b16310d0cd..2da63d0ad8 100644 --- a/reactive/kotlinx-coroutines-reactive/test/PublisherCompletionStressTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/PublisherCompletionStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/PublisherMultiTest.kt b/reactive/kotlinx-coroutines-reactive/test/PublisherMultiTest.kt index 4a552b5f8d..22762bb065 100644 --- a/reactive/kotlinx-coroutines-reactive/test/PublisherMultiTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/PublisherMultiTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/PublisherRequestStressTest.kt b/reactive/kotlinx-coroutines-reactive/test/PublisherRequestStressTest.kt index a19ce2f49a..f3b0428b67 100644 --- a/reactive/kotlinx-coroutines-reactive/test/PublisherRequestStressTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/PublisherRequestStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/PublisherSubscriptionSelectTest.kt b/reactive/kotlinx-coroutines-reactive/test/PublisherSubscriptionSelectTest.kt index 740fd86ae4..3589d4855d 100644 --- a/reactive/kotlinx-coroutines-reactive/test/PublisherSubscriptionSelectTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/PublisherSubscriptionSelectTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/RangePublisherBufferedTest.kt b/reactive/kotlinx-coroutines-reactive/test/RangePublisherBufferedTest.kt index b710c59064..da1f3cced9 100644 --- a/reactive/kotlinx-coroutines-reactive/test/RangePublisherBufferedTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/RangePublisherBufferedTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.flow.* diff --git a/reactive/kotlinx-coroutines-reactive/test/RangePublisherTest.kt b/reactive/kotlinx-coroutines-reactive/test/RangePublisherTest.kt index 72d5de5e82..9d1f85a2fa 100644 --- a/reactive/kotlinx-coroutines-reactive/test/RangePublisherTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/RangePublisherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import org.junit.* diff --git a/reactive/kotlinx-coroutines-reactive/test/ReactiveStreamTckTest.kt b/reactive/kotlinx-coroutines-reactive/test/ReactiveStreamTckTest.kt index a251d98371..74d082d031 100644 --- a/reactive/kotlinx-coroutines-reactive/test/ReactiveStreamTckTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/ReactiveStreamTckTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactive/test/UnboundedIntegerIncrementPublisherTest.kt b/reactive/kotlinx-coroutines-reactive/test/UnboundedIntegerIncrementPublisherTest.kt index 63d444c19e..c602a0cb1c 100644 --- a/reactive/kotlinx-coroutines-reactive/test/UnboundedIntegerIncrementPublisherTest.kt +++ b/reactive/kotlinx-coroutines-reactive/test/UnboundedIntegerIncrementPublisherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactive import org.junit.* diff --git a/reactive/kotlinx-coroutines-reactor/build.gradle.kts b/reactive/kotlinx-coroutines-reactor/build.gradle.kts index 8dc419f472..49dd0ae675 100644 --- a/reactive/kotlinx-coroutines-reactor/build.gradle.kts +++ b/reactive/kotlinx-coroutines-reactor/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import org.jetbrains.kotlin.gradle.dsl.* plugins { diff --git a/reactive/kotlinx-coroutines-reactor/src/Convert.kt b/reactive/kotlinx-coroutines-reactor/src/Convert.kt index efdedf78ea..97a2649f1b 100644 --- a/reactive/kotlinx-coroutines-reactor/src/Convert.kt +++ b/reactive/kotlinx-coroutines-reactor/src/Convert.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/src/Flux.kt b/reactive/kotlinx-coroutines-reactor/src/Flux.kt index 1e408d83e5..e0355e2e30 100644 --- a/reactive/kotlinx-coroutines-reactor/src/Flux.kt +++ b/reactive/kotlinx-coroutines-reactor/src/Flux.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/src/Migration.kt b/reactive/kotlinx-coroutines-reactor/src/Migration.kt index 8da0db2d59..dc13142b76 100644 --- a/reactive/kotlinx-coroutines-reactor/src/Migration.kt +++ b/reactive/kotlinx-coroutines-reactor/src/Migration.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:JvmName("FlowKt") package kotlinx.coroutines.reactor diff --git a/reactive/kotlinx-coroutines-reactor/src/Mono.kt b/reactive/kotlinx-coroutines-reactor/src/Mono.kt index 27dea603e9..f8c0752419 100644 --- a/reactive/kotlinx-coroutines-reactor/src/Mono.kt +++ b/reactive/kotlinx-coroutines-reactor/src/Mono.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("INVISIBLE_REFERENCE", "INVISIBLE_MEMBER") package kotlinx.coroutines.reactor diff --git a/reactive/kotlinx-coroutines-reactor/src/ReactorContext.kt b/reactive/kotlinx-coroutines-reactor/src/ReactorContext.kt index 912fb6e577..db464c803d 100644 --- a/reactive/kotlinx-coroutines-reactor/src/ReactorContext.kt +++ b/reactive/kotlinx-coroutines-reactor/src/ReactorContext.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlin.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/src/ReactorContextInjector.kt b/reactive/kotlinx-coroutines-reactor/src/ReactorContextInjector.kt index f65d2ec2f0..7a5debf001 100644 --- a/reactive/kotlinx-coroutines-reactor/src/ReactorContextInjector.kt +++ b/reactive/kotlinx-coroutines-reactor/src/ReactorContextInjector.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.reactive.* diff --git a/reactive/kotlinx-coroutines-reactor/src/ReactorFlow.kt b/reactive/kotlinx-coroutines-reactor/src/ReactorFlow.kt index 6a77bbf3a6..ba819774ec 100644 --- a/reactive/kotlinx-coroutines-reactor/src/ReactorFlow.kt +++ b/reactive/kotlinx-coroutines-reactor/src/ReactorFlow.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/src/Scheduler.kt b/reactive/kotlinx-coroutines-reactor/src/Scheduler.kt index 03b052b6b1..d780f51a4e 100644 --- a/reactive/kotlinx-coroutines-reactor/src/Scheduler.kt +++ b/reactive/kotlinx-coroutines-reactor/src/Scheduler.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/test/BackpressureTest.kt b/reactive/kotlinx-coroutines-reactor/test/BackpressureTest.kt index 3d6398aa13..78427f0132 100644 --- a/reactive/kotlinx-coroutines-reactor/test/BackpressureTest.kt +++ b/reactive/kotlinx-coroutines-reactor/test/BackpressureTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/test/Check.kt b/reactive/kotlinx-coroutines-reactor/test/Check.kt index e092a6ca1e..d5a9a57df6 100644 --- a/reactive/kotlinx-coroutines-reactor/test/Check.kt +++ b/reactive/kotlinx-coroutines-reactor/test/Check.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import reactor.core.publisher.Flux diff --git a/reactive/kotlinx-coroutines-reactor/test/ConvertTest.kt b/reactive/kotlinx-coroutines-reactor/test/ConvertTest.kt index 8af6d3c455..70ee6888e3 100644 --- a/reactive/kotlinx-coroutines-reactor/test/ConvertTest.kt +++ b/reactive/kotlinx-coroutines-reactor/test/ConvertTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/test/FluxCompletionStressTest.kt b/reactive/kotlinx-coroutines-reactor/test/FluxCompletionStressTest.kt index 6090408f97..122cf6a161 100644 --- a/reactive/kotlinx-coroutines-reactor/test/FluxCompletionStressTest.kt +++ b/reactive/kotlinx-coroutines-reactor/test/FluxCompletionStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/test/FluxContextTest.kt b/reactive/kotlinx-coroutines-reactor/test/FluxContextTest.kt index 1ed3a164f6..81c0e82146 100644 --- a/reactive/kotlinx-coroutines-reactor/test/FluxContextTest.kt +++ b/reactive/kotlinx-coroutines-reactor/test/FluxContextTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/test/FluxMultiTest.kt b/reactive/kotlinx-coroutines-reactor/test/FluxMultiTest.kt index 0d5f9e2c18..8254b82467 100644 --- a/reactive/kotlinx-coroutines-reactor/test/FluxMultiTest.kt +++ b/reactive/kotlinx-coroutines-reactor/test/FluxMultiTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/test/FluxSingleTest.kt b/reactive/kotlinx-coroutines-reactor/test/FluxSingleTest.kt index 3879c62c71..ebce20f86a 100644 --- a/reactive/kotlinx-coroutines-reactor/test/FluxSingleTest.kt +++ b/reactive/kotlinx-coroutines-reactor/test/FluxSingleTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/test/FluxTest.kt b/reactive/kotlinx-coroutines-reactor/test/FluxTest.kt index f575af4101..860be09222 100644 --- a/reactive/kotlinx-coroutines-reactor/test/FluxTest.kt +++ b/reactive/kotlinx-coroutines-reactor/test/FluxTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/test/MonoAwaitStressTest.kt b/reactive/kotlinx-coroutines-reactor/test/MonoAwaitStressTest.kt index 355aa686ea..f02b064106 100644 --- a/reactive/kotlinx-coroutines-reactor/test/MonoAwaitStressTest.kt +++ b/reactive/kotlinx-coroutines-reactor/test/MonoAwaitStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/test/MonoTest.kt b/reactive/kotlinx-coroutines-reactor/test/MonoTest.kt index 2a5e5dc107..4ebcc7496c 100644 --- a/reactive/kotlinx-coroutines-reactor/test/MonoTest.kt +++ b/reactive/kotlinx-coroutines-reactor/test/MonoTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-reactor/test/SchedulerTest.kt b/reactive/kotlinx-coroutines-reactor/test/SchedulerTest.kt index bed607c9ed..b945c5262b 100644 --- a/reactive/kotlinx-coroutines-reactor/test/SchedulerTest.kt +++ b/reactive/kotlinx-coroutines-reactor/test/SchedulerTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.reactor import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx2/build.gradle b/reactive/kotlinx-coroutines-rx2/build.gradle index 989406c10b..477fc24354 100644 --- a/reactive/kotlinx-coroutines-rx2/build.gradle +++ b/reactive/kotlinx-coroutines-rx2/build.gradle @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ import org.jetbrains.dokka.gradle.DokkaTaskPartial dependencies { diff --git a/reactive/kotlinx-coroutines-rx2/src/RxAwait.kt b/reactive/kotlinx-coroutines-rx2/src/RxAwait.kt index aeaa1f4b26..f59a1fd504 100644 --- a/reactive/kotlinx-coroutines-rx2/src/RxAwait.kt +++ b/reactive/kotlinx-coroutines-rx2/src/RxAwait.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/src/RxCancellable.kt b/reactive/kotlinx-coroutines-rx2/src/RxCancellable.kt index 3e39033ed7..b0154982dc 100644 --- a/reactive/kotlinx-coroutines-rx2/src/RxCancellable.kt +++ b/reactive/kotlinx-coroutines-rx2/src/RxCancellable.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.functions.* diff --git a/reactive/kotlinx-coroutines-rx2/src/RxChannel.kt b/reactive/kotlinx-coroutines-rx2/src/RxChannel.kt index 94c9c2224c..0235468b94 100644 --- a/reactive/kotlinx-coroutines-rx2/src/RxChannel.kt +++ b/reactive/kotlinx-coroutines-rx2/src/RxChannel.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/src/RxCompletable.kt b/reactive/kotlinx-coroutines-rx2/src/RxCompletable.kt index e4670f3579..f1dc93d34f 100644 --- a/reactive/kotlinx-coroutines-rx2/src/RxCompletable.kt +++ b/reactive/kotlinx-coroutines-rx2/src/RxCompletable.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/src/RxConvert.kt b/reactive/kotlinx-coroutines-rx2/src/RxConvert.kt index a92d68e289..980fb17693 100644 --- a/reactive/kotlinx-coroutines-rx2/src/RxConvert.kt +++ b/reactive/kotlinx-coroutines-rx2/src/RxConvert.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/src/RxFlowable.kt b/reactive/kotlinx-coroutines-rx2/src/RxFlowable.kt index c856bb4e18..05cc0c653e 100644 --- a/reactive/kotlinx-coroutines-rx2/src/RxFlowable.kt +++ b/reactive/kotlinx-coroutines-rx2/src/RxFlowable.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("INVISIBLE_REFERENCE", "INVISIBLE_MEMBER") package kotlinx.coroutines.rx2 diff --git a/reactive/kotlinx-coroutines-rx2/src/RxMaybe.kt b/reactive/kotlinx-coroutines-rx2/src/RxMaybe.kt index ab713123d9..ad846efb15 100644 --- a/reactive/kotlinx-coroutines-rx2/src/RxMaybe.kt +++ b/reactive/kotlinx-coroutines-rx2/src/RxMaybe.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/src/RxObservable.kt b/reactive/kotlinx-coroutines-rx2/src/RxObservable.kt index 2da5096804..d9c939236c 100644 --- a/reactive/kotlinx-coroutines-rx2/src/RxObservable.kt +++ b/reactive/kotlinx-coroutines-rx2/src/RxObservable.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/src/RxScheduler.kt b/reactive/kotlinx-coroutines-rx2/src/RxScheduler.kt index 1b65f9b36c..bac20210f6 100644 --- a/reactive/kotlinx-coroutines-rx2/src/RxScheduler.kt +++ b/reactive/kotlinx-coroutines-rx2/src/RxScheduler.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/src/RxSingle.kt b/reactive/kotlinx-coroutines-rx2/src/RxSingle.kt index 27842a21ae..1bdbaa5bcd 100644 --- a/reactive/kotlinx-coroutines-rx2/src/RxSingle.kt +++ b/reactive/kotlinx-coroutines-rx2/src/RxSingle.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/BackpressureTest.kt b/reactive/kotlinx-coroutines-rx2/test/BackpressureTest.kt index ed0bc369c0..497f94e1d7 100644 --- a/reactive/kotlinx-coroutines-rx2/test/BackpressureTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/BackpressureTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/Check.kt b/reactive/kotlinx-coroutines-rx2/test/Check.kt index beb2c43a3d..ded4b7aed5 100644 --- a/reactive/kotlinx-coroutines-rx2/test/Check.kt +++ b/reactive/kotlinx-coroutines-rx2/test/Check.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/CompletableTest.kt b/reactive/kotlinx-coroutines-rx2/test/CompletableTest.kt index 16f0005ba1..c1fb4d07b5 100644 --- a/reactive/kotlinx-coroutines-rx2/test/CompletableTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/CompletableTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/ConvertTest.kt b/reactive/kotlinx-coroutines-rx2/test/ConvertTest.kt index cfc3240741..1bf53d26b0 100644 --- a/reactive/kotlinx-coroutines-rx2/test/ConvertTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/ConvertTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx2/test/FlowAsFlowableTest.kt b/reactive/kotlinx-coroutines-rx2/test/FlowAsFlowableTest.kt index 1cbded6dc3..41e25fe094 100644 --- a/reactive/kotlinx-coroutines-rx2/test/FlowAsFlowableTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/FlowAsFlowableTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx2/test/FlowAsObservableTest.kt b/reactive/kotlinx-coroutines-rx2/test/FlowAsObservableTest.kt index 3cde182260..a85f7c7f7a 100644 --- a/reactive/kotlinx-coroutines-rx2/test/FlowAsObservableTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/FlowAsObservableTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/FlowableContextTest.kt b/reactive/kotlinx-coroutines-rx2/test/FlowableContextTest.kt index 2cc3243551..692f4c289d 100644 --- a/reactive/kotlinx-coroutines-rx2/test/FlowableContextTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/FlowableContextTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/FlowableExceptionHandlingTest.kt b/reactive/kotlinx-coroutines-rx2/test/FlowableExceptionHandlingTest.kt index 316439293f..e079631db3 100644 --- a/reactive/kotlinx-coroutines-rx2/test/FlowableExceptionHandlingTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/FlowableExceptionHandlingTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.exceptions.* diff --git a/reactive/kotlinx-coroutines-rx2/test/FlowableTest.kt b/reactive/kotlinx-coroutines-rx2/test/FlowableTest.kt index 148d1f9999..ef20747671 100644 --- a/reactive/kotlinx-coroutines-rx2/test/FlowableTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/FlowableTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx2/test/IntegrationTest.kt b/reactive/kotlinx-coroutines-rx2/test/IntegrationTest.kt index 8a6362ad99..652afe5fde 100644 --- a/reactive/kotlinx-coroutines-rx2/test/IntegrationTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/IntegrationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/IterableFlowAsFlowableTckTest.kt b/reactive/kotlinx-coroutines-rx2/test/IterableFlowAsFlowableTckTest.kt index cc22e33ada..89423a8331 100644 --- a/reactive/kotlinx-coroutines-rx2/test/IterableFlowAsFlowableTckTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/IterableFlowAsFlowableTckTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/LeakedExceptionTest.kt b/reactive/kotlinx-coroutines-rx2/test/LeakedExceptionTest.kt index 7252ca2132..89f74145ed 100644 --- a/reactive/kotlinx-coroutines-rx2/test/LeakedExceptionTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/LeakedExceptionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/MaybeTest.kt b/reactive/kotlinx-coroutines-rx2/test/MaybeTest.kt index f5d128d311..5206a336a1 100644 --- a/reactive/kotlinx-coroutines-rx2/test/MaybeTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/MaybeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/ObservableAsFlowTest.kt b/reactive/kotlinx-coroutines-rx2/test/ObservableAsFlowTest.kt index c14c3cc4e8..0a5cacba5b 100644 --- a/reactive/kotlinx-coroutines-rx2/test/ObservableAsFlowTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/ObservableAsFlowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.Observable diff --git a/reactive/kotlinx-coroutines-rx2/test/ObservableCollectTest.kt b/reactive/kotlinx-coroutines-rx2/test/ObservableCollectTest.kt index 508f594ac3..1efaa939ea 100644 --- a/reactive/kotlinx-coroutines-rx2/test/ObservableCollectTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/ObservableCollectTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/ObservableCompletionStressTest.kt b/reactive/kotlinx-coroutines-rx2/test/ObservableCompletionStressTest.kt index 7e1d335028..52b1f89123 100644 --- a/reactive/kotlinx-coroutines-rx2/test/ObservableCompletionStressTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/ObservableCompletionStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx2/test/ObservableExceptionHandlingTest.kt b/reactive/kotlinx-coroutines-rx2/test/ObservableExceptionHandlingTest.kt index fb3d0f69fc..66a4a305ab 100644 --- a/reactive/kotlinx-coroutines-rx2/test/ObservableExceptionHandlingTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/ObservableExceptionHandlingTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.exceptions.* diff --git a/reactive/kotlinx-coroutines-rx2/test/ObservableMultiTest.kt b/reactive/kotlinx-coroutines-rx2/test/ObservableMultiTest.kt index 7023211450..7471c6de67 100644 --- a/reactive/kotlinx-coroutines-rx2/test/ObservableMultiTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/ObservableMultiTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/ObservableSingleTest.kt b/reactive/kotlinx-coroutines-rx2/test/ObservableSingleTest.kt index e246407a17..acb0251de5 100644 --- a/reactive/kotlinx-coroutines-rx2/test/ObservableSingleTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/ObservableSingleTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/ObservableSourceAsFlowStressTest.kt b/reactive/kotlinx-coroutines-rx2/test/ObservableSourceAsFlowStressTest.kt index 0253fcedd8..f953241673 100644 --- a/reactive/kotlinx-coroutines-rx2/test/ObservableSourceAsFlowStressTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/ObservableSourceAsFlowStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/ObservableSubscriptionSelectTest.kt b/reactive/kotlinx-coroutines-rx2/test/ObservableSubscriptionSelectTest.kt index 2c22cbf035..01a468c614 100644 --- a/reactive/kotlinx-coroutines-rx2/test/ObservableSubscriptionSelectTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/ObservableSubscriptionSelectTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx2/test/ObservableTest.kt b/reactive/kotlinx-coroutines-rx2/test/ObservableTest.kt index 4f7fa547d2..f85d4d2488 100644 --- a/reactive/kotlinx-coroutines-rx2/test/ObservableTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/ObservableTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/SchedulerStressTest.kt b/reactive/kotlinx-coroutines-rx2/test/SchedulerStressTest.kt index ea33a9fa58..c467c8f6df 100644 --- a/reactive/kotlinx-coroutines-rx2/test/SchedulerStressTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/SchedulerStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx2/test/SchedulerTest.kt b/reactive/kotlinx-coroutines-rx2/test/SchedulerTest.kt index 194186718d..1ba1532122 100644 --- a/reactive/kotlinx-coroutines-rx2/test/SchedulerTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/SchedulerTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx2/test/SingleTest.kt b/reactive/kotlinx-coroutines-rx2/test/SingleTest.kt index b359d963b8..cb75d51f80 100644 --- a/reactive/kotlinx-coroutines-rx2/test/SingleTest.kt +++ b/reactive/kotlinx-coroutines-rx2/test/SingleTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx2 import io.reactivex.* diff --git a/reactive/kotlinx-coroutines-rx3/build.gradle b/reactive/kotlinx-coroutines-rx3/build.gradle index 87c39f4ae5..b5c05ae865 100644 --- a/reactive/kotlinx-coroutines-rx3/build.gradle +++ b/reactive/kotlinx-coroutines-rx3/build.gradle @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ import org.jetbrains.dokka.gradle.DokkaTaskPartial targetCompatibility = JavaVersion.VERSION_1_8 diff --git a/reactive/kotlinx-coroutines-rx3/src/RxAwait.kt b/reactive/kotlinx-coroutines-rx3/src/RxAwait.kt index 33ec848840..6e75c2b135 100644 --- a/reactive/kotlinx-coroutines-rx3/src/RxAwait.kt +++ b/reactive/kotlinx-coroutines-rx3/src/RxAwait.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/src/RxCancellable.kt b/reactive/kotlinx-coroutines-rx3/src/RxCancellable.kt index 1017b112f1..041c5a2ded 100644 --- a/reactive/kotlinx-coroutines-rx3/src/RxCancellable.kt +++ b/reactive/kotlinx-coroutines-rx3/src/RxCancellable.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.functions.* diff --git a/reactive/kotlinx-coroutines-rx3/src/RxChannel.kt b/reactive/kotlinx-coroutines-rx3/src/RxChannel.kt index 614494438e..d65dde0534 100644 --- a/reactive/kotlinx-coroutines-rx3/src/RxChannel.kt +++ b/reactive/kotlinx-coroutines-rx3/src/RxChannel.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/src/RxCompletable.kt b/reactive/kotlinx-coroutines-rx3/src/RxCompletable.kt index 47cc6ad3ab..87f302fe8b 100644 --- a/reactive/kotlinx-coroutines-rx3/src/RxCompletable.kt +++ b/reactive/kotlinx-coroutines-rx3/src/RxCompletable.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/src/RxConvert.kt b/reactive/kotlinx-coroutines-rx3/src/RxConvert.kt index 57d2dfb370..a3731f85ab 100644 --- a/reactive/kotlinx-coroutines-rx3/src/RxConvert.kt +++ b/reactive/kotlinx-coroutines-rx3/src/RxConvert.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/src/RxFlowable.kt b/reactive/kotlinx-coroutines-rx3/src/RxFlowable.kt index 9357f2834a..0dfd68c836 100644 --- a/reactive/kotlinx-coroutines-rx3/src/RxFlowable.kt +++ b/reactive/kotlinx-coroutines-rx3/src/RxFlowable.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/src/RxMaybe.kt b/reactive/kotlinx-coroutines-rx3/src/RxMaybe.kt index defb2b725d..abc59a26bc 100644 --- a/reactive/kotlinx-coroutines-rx3/src/RxMaybe.kt +++ b/reactive/kotlinx-coroutines-rx3/src/RxMaybe.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/src/RxObservable.kt b/reactive/kotlinx-coroutines-rx3/src/RxObservable.kt index 4123531a69..0b26f47e66 100644 --- a/reactive/kotlinx-coroutines-rx3/src/RxObservable.kt +++ b/reactive/kotlinx-coroutines-rx3/src/RxObservable.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/src/RxScheduler.kt b/reactive/kotlinx-coroutines-rx3/src/RxScheduler.kt index 2ef0fc1d92..8f77d4c867 100644 --- a/reactive/kotlinx-coroutines-rx3/src/RxScheduler.kt +++ b/reactive/kotlinx-coroutines-rx3/src/RxScheduler.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/src/RxSingle.kt b/reactive/kotlinx-coroutines-rx3/src/RxSingle.kt index e7678f0d10..b424a149bc 100644 --- a/reactive/kotlinx-coroutines-rx3/src/RxSingle.kt +++ b/reactive/kotlinx-coroutines-rx3/src/RxSingle.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/BackpressureTest.kt b/reactive/kotlinx-coroutines-rx3/test/BackpressureTest.kt index 9cec4833a1..0317c71fd5 100644 --- a/reactive/kotlinx-coroutines-rx3/test/BackpressureTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/BackpressureTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/Check.kt b/reactive/kotlinx-coroutines-rx3/test/Check.kt index 37a1b324eb..c1e6d2ed00 100644 --- a/reactive/kotlinx-coroutines-rx3/test/Check.kt +++ b/reactive/kotlinx-coroutines-rx3/test/Check.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/CompletableTest.kt b/reactive/kotlinx-coroutines-rx3/test/CompletableTest.kt index cfdb6d4170..eab8129567 100644 --- a/reactive/kotlinx-coroutines-rx3/test/CompletableTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/CompletableTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/ConvertTest.kt b/reactive/kotlinx-coroutines-rx3/test/ConvertTest.kt index e2fe533552..3f0ed7fc80 100644 --- a/reactive/kotlinx-coroutines-rx3/test/ConvertTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/ConvertTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx3/test/FlowAsFlowableTest.kt b/reactive/kotlinx-coroutines-rx3/test/FlowAsFlowableTest.kt index a73fee469e..3090c815f3 100644 --- a/reactive/kotlinx-coroutines-rx3/test/FlowAsFlowableTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/FlowAsFlowableTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx3/test/FlowAsObservableTest.kt b/reactive/kotlinx-coroutines-rx3/test/FlowAsObservableTest.kt index 5759f9f426..359e48acca 100644 --- a/reactive/kotlinx-coroutines-rx3/test/FlowAsObservableTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/FlowAsObservableTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/FlowableContextTest.kt b/reactive/kotlinx-coroutines-rx3/test/FlowableContextTest.kt index b70e0d5135..b417205c57 100644 --- a/reactive/kotlinx-coroutines-rx3/test/FlowableContextTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/FlowableContextTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/FlowableExceptionHandlingTest.kt b/reactive/kotlinx-coroutines-rx3/test/FlowableExceptionHandlingTest.kt index 126cb81826..9db7aeee8a 100644 --- a/reactive/kotlinx-coroutines-rx3/test/FlowableExceptionHandlingTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/FlowableExceptionHandlingTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.exceptions.* diff --git a/reactive/kotlinx-coroutines-rx3/test/FlowableTest.kt b/reactive/kotlinx-coroutines-rx3/test/FlowableTest.kt index 746d6e8b41..969adc8bdc 100644 --- a/reactive/kotlinx-coroutines-rx3/test/FlowableTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/FlowableTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx3/test/IntegrationTest.kt b/reactive/kotlinx-coroutines-rx3/test/IntegrationTest.kt index 1302124f50..3cee26352f 100644 --- a/reactive/kotlinx-coroutines-rx3/test/IntegrationTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/IntegrationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/IterableFlowAsFlowableTckTest.kt b/reactive/kotlinx-coroutines-rx3/test/IterableFlowAsFlowableTckTest.kt index 8e54922d4a..295f055ee7 100644 --- a/reactive/kotlinx-coroutines-rx3/test/IterableFlowAsFlowableTckTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/IterableFlowAsFlowableTckTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/LeakedExceptionTest.kt b/reactive/kotlinx-coroutines-rx3/test/LeakedExceptionTest.kt index 028ded0dd0..1b17e2abb0 100644 --- a/reactive/kotlinx-coroutines-rx3/test/LeakedExceptionTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/LeakedExceptionTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/MaybeTest.kt b/reactive/kotlinx-coroutines-rx3/test/MaybeTest.kt index bea939efde..969b9d8d58 100644 --- a/reactive/kotlinx-coroutines-rx3/test/MaybeTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/MaybeTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/ObservableAsFlowTest.kt b/reactive/kotlinx-coroutines-rx3/test/ObservableAsFlowTest.kt index 262da9ac1b..354245085d 100644 --- a/reactive/kotlinx-coroutines-rx3/test/ObservableAsFlowTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/ObservableAsFlowTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.Observable diff --git a/reactive/kotlinx-coroutines-rx3/test/ObservableCollectTest.kt b/reactive/kotlinx-coroutines-rx3/test/ObservableCollectTest.kt index 680786f9b3..aebc15e299 100644 --- a/reactive/kotlinx-coroutines-rx3/test/ObservableCollectTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/ObservableCollectTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.ObservableSource diff --git a/reactive/kotlinx-coroutines-rx3/test/ObservableCompletionStressTest.kt b/reactive/kotlinx-coroutines-rx3/test/ObservableCompletionStressTest.kt index c1d25bcb51..37bf71ee3f 100644 --- a/reactive/kotlinx-coroutines-rx3/test/ObservableCompletionStressTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/ObservableCompletionStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx3/test/ObservableExceptionHandlingTest.kt b/reactive/kotlinx-coroutines-rx3/test/ObservableExceptionHandlingTest.kt index 5ddb36ed07..127615397b 100644 --- a/reactive/kotlinx-coroutines-rx3/test/ObservableExceptionHandlingTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/ObservableExceptionHandlingTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.exceptions.* diff --git a/reactive/kotlinx-coroutines-rx3/test/ObservableMultiTest.kt b/reactive/kotlinx-coroutines-rx3/test/ObservableMultiTest.kt index d7c799db1c..cddacac1a7 100644 --- a/reactive/kotlinx-coroutines-rx3/test/ObservableMultiTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/ObservableMultiTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/ObservableSingleTest.kt b/reactive/kotlinx-coroutines-rx3/test/ObservableSingleTest.kt index 692f014418..60deb3ddc4 100644 --- a/reactive/kotlinx-coroutines-rx3/test/ObservableSingleTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/ObservableSingleTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/ObservableSourceAsFlowStressTest.kt b/reactive/kotlinx-coroutines-rx3/test/ObservableSourceAsFlowStressTest.kt index 01d6a20e36..8fbd3da3db 100644 --- a/reactive/kotlinx-coroutines-rx3/test/ObservableSourceAsFlowStressTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/ObservableSourceAsFlowStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/ObservableSubscriptionSelectTest.kt b/reactive/kotlinx-coroutines-rx3/test/ObservableSubscriptionSelectTest.kt index 58a54616f6..f54e2e1a02 100644 --- a/reactive/kotlinx-coroutines-rx3/test/ObservableSubscriptionSelectTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/ObservableSubscriptionSelectTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx3/test/ObservableTest.kt b/reactive/kotlinx-coroutines-rx3/test/ObservableTest.kt index c6a6be56e3..619c6ad21b 100644 --- a/reactive/kotlinx-coroutines-rx3/test/ObservableTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/ObservableTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/SchedulerStressTest.kt b/reactive/kotlinx-coroutines-rx3/test/SchedulerStressTest.kt index 5abb511d72..66ea65544c 100644 --- a/reactive/kotlinx-coroutines-rx3/test/SchedulerStressTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/SchedulerStressTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import kotlinx.coroutines.* diff --git a/reactive/kotlinx-coroutines-rx3/test/SchedulerTest.kt b/reactive/kotlinx-coroutines-rx3/test/SchedulerTest.kt index c966cdfd08..0b1ccc36f8 100644 --- a/reactive/kotlinx-coroutines-rx3/test/SchedulerTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/SchedulerTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/reactive/kotlinx-coroutines-rx3/test/SingleTest.kt b/reactive/kotlinx-coroutines-rx3/test/SingleTest.kt index 3e763aa58c..5efa2f8319 100644 --- a/reactive/kotlinx-coroutines-rx3/test/SingleTest.kt +++ b/reactive/kotlinx-coroutines-rx3/test/SingleTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.rx3 import io.reactivex.rxjava3.core.* diff --git a/settings.gradle b/settings.gradle index 09fa9635f2..f9870c61eb 100644 --- a/settings.gradle +++ b/settings.gradle @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - pluginManagement { plugins { id "org.openjfx.javafxplugin" version javafx_plugin_version diff --git a/ui/knit.code.include b/ui/knit.code.include index adf195784e..c5a3e5700a 100644 --- a/ui/knit.code.include +++ b/ui/knit.code.include @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from ${file.name} by Knit tool. Do not edit. package ${knit.package}.${knit.name} diff --git a/ui/knit.properties b/ui/knit.properties index 76a1d77a99..5bb873ac4c 100644 --- a/ui/knit.properties +++ b/ui/knit.properties @@ -1,7 +1,3 @@ -# -# Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. -# - knit.dir=kotlinx-coroutines-javafx/test/guide/ knit.package=kotlinx.coroutines.javafx.guide knit.include=knit.code.include diff --git a/ui/kotlinx-coroutines-android/android-unit-tests/build.gradle.kts b/ui/kotlinx-coroutines-android/android-unit-tests/build.gradle.kts index 625ce728b1..2f01e03d35 100644 --- a/ui/kotlinx-coroutines-android/android-unit-tests/build.gradle.kts +++ b/ui/kotlinx-coroutines-android/android-unit-tests/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - project.configureAar() dependencies { diff --git a/ui/kotlinx-coroutines-android/android-unit-tests/src/EmptyCoroutineScopeImpl.kt b/ui/kotlinx-coroutines-android/android-unit-tests/src/EmptyCoroutineScopeImpl.kt index 1c5c6abd81..d1f920013c 100644 --- a/ui/kotlinx-coroutines-android/android-unit-tests/src/EmptyCoroutineScopeImpl.kt +++ b/ui/kotlinx-coroutines-android/android-unit-tests/src/EmptyCoroutineScopeImpl.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.android import kotlinx.coroutines.* diff --git a/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/CustomizedRobolectricTest.kt b/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/CustomizedRobolectricTest.kt index 676ee4310d..7b60938043 100644 --- a/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/CustomizedRobolectricTest.kt +++ b/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/CustomizedRobolectricTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package ordered.tests import kotlinx.coroutines.* diff --git a/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/FirstMockedMainTest.kt b/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/FirstMockedMainTest.kt index c134ec5f89..216dcf6368 100644 --- a/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/FirstMockedMainTest.kt +++ b/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/FirstMockedMainTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package ordered.tests import kotlinx.coroutines.* diff --git a/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/FirstRobolectricTest.kt b/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/FirstRobolectricTest.kt index 99744f897f..8777ed939d 100644 --- a/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/FirstRobolectricTest.kt +++ b/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/FirstRobolectricTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package ordered.tests import kotlinx.coroutines.* diff --git a/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/MockedMainTest.kt b/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/MockedMainTest.kt index d68d9eb6f6..221186e688 100644 --- a/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/MockedMainTest.kt +++ b/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/MockedMainTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package ordered.tests class MockedMainTest : FirstMockedMainTest() diff --git a/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/RobolectricTest.kt b/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/RobolectricTest.kt index 4213cb414d..eff0c33870 100644 --- a/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/RobolectricTest.kt +++ b/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/RobolectricTest.kt @@ -1,6 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ package ordered.tests open class RobolectricTest : FirstRobolectricTest() diff --git a/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/TestComponent.kt b/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/TestComponent.kt index c677d9911a..fbd6d8135a 100644 --- a/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/TestComponent.kt +++ b/ui/kotlinx-coroutines-android/android-unit-tests/test/ordered/tests/TestComponent.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package ordered.tests import kotlinx.coroutines.* diff --git a/ui/kotlinx-coroutines-android/build.gradle.kts b/ui/kotlinx-coroutines-android/build.gradle.kts index d757d11d45..a09d02ca75 100644 --- a/ui/kotlinx-coroutines-android/build.gradle.kts +++ b/ui/kotlinx-coroutines-android/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - import kotlinx.kover.api.* configurations { diff --git a/ui/kotlinx-coroutines-android/src/AndroidExceptionPreHandler.kt b/ui/kotlinx-coroutines-android/src/AndroidExceptionPreHandler.kt index 0bc603ea1e..d622f350c2 100644 --- a/ui/kotlinx-coroutines-android/src/AndroidExceptionPreHandler.kt +++ b/ui/kotlinx-coroutines-android/src/AndroidExceptionPreHandler.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.android import android.os.* diff --git a/ui/kotlinx-coroutines-android/src/HandlerDispatcher.kt b/ui/kotlinx-coroutines-android/src/HandlerDispatcher.kt index 065bb2af49..5ce3315db2 100644 --- a/ui/kotlinx-coroutines-android/src/HandlerDispatcher.kt +++ b/ui/kotlinx-coroutines-android/src/HandlerDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - @file:Suppress("unused") package kotlinx.coroutines.android diff --git a/ui/kotlinx-coroutines-android/test/AndroidExceptionPreHandlerTest.kt b/ui/kotlinx-coroutines-android/test/AndroidExceptionPreHandlerTest.kt index 1220797009..c8a829e726 100644 --- a/ui/kotlinx-coroutines-android/test/AndroidExceptionPreHandlerTest.kt +++ b/ui/kotlinx-coroutines-android/test/AndroidExceptionPreHandlerTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.android import kotlinx.coroutines.* diff --git a/ui/kotlinx-coroutines-android/test/DisabledHandlerTest.kt b/ui/kotlinx-coroutines-android/test/DisabledHandlerTest.kt index a5b5ec95ee..e281c8d195 100644 --- a/ui/kotlinx-coroutines-android/test/DisabledHandlerTest.kt +++ b/ui/kotlinx-coroutines-android/test/DisabledHandlerTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.android import android.os.* diff --git a/ui/kotlinx-coroutines-android/test/HandlerDispatcherAsyncTest.kt b/ui/kotlinx-coroutines-android/test/HandlerDispatcherAsyncTest.kt index c2091f339f..bf9beb64f6 100644 --- a/ui/kotlinx-coroutines-android/test/HandlerDispatcherAsyncTest.kt +++ b/ui/kotlinx-coroutines-android/test/HandlerDispatcherAsyncTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.android import android.os.* diff --git a/ui/kotlinx-coroutines-android/test/HandlerDispatcherTest.kt b/ui/kotlinx-coroutines-android/test/HandlerDispatcherTest.kt index 9fc40d33ac..3526a37a85 100644 --- a/ui/kotlinx-coroutines-android/test/HandlerDispatcherTest.kt +++ b/ui/kotlinx-coroutines-android/test/HandlerDispatcherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2022 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.android import android.os.* diff --git a/ui/kotlinx-coroutines-android/test/R8ServiceLoaderOptimizationTest.kt b/ui/kotlinx-coroutines-android/test/R8ServiceLoaderOptimizationTest.kt index 47beb85bbf..a131e81694 100644 --- a/ui/kotlinx-coroutines-android/test/R8ServiceLoaderOptimizationTest.kt +++ b/ui/kotlinx-coroutines-android/test/R8ServiceLoaderOptimizationTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2019 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.android import kotlinx.coroutines.* diff --git a/ui/kotlinx-coroutines-javafx/build.gradle.kts b/ui/kotlinx-coroutines-javafx/build.gradle.kts index d11304e4a7..355da2ac0d 100644 --- a/ui/kotlinx-coroutines-javafx/build.gradle.kts +++ b/ui/kotlinx-coroutines-javafx/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - plugins { id("org.openjfx.javafxplugin") version "0.0.14" } diff --git a/ui/kotlinx-coroutines-javafx/src/JavaFxConvert.kt b/ui/kotlinx-coroutines-javafx/src/JavaFxConvert.kt index ebeaa3b84b..8e9bfffd1e 100644 --- a/ui/kotlinx-coroutines-javafx/src/JavaFxConvert.kt +++ b/ui/kotlinx-coroutines-javafx/src/JavaFxConvert.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.javafx import javafx.beans.value.* diff --git a/ui/kotlinx-coroutines-javafx/src/JavaFxDispatcher.kt b/ui/kotlinx-coroutines-javafx/src/JavaFxDispatcher.kt index 61583aad65..941f458282 100644 --- a/ui/kotlinx-coroutines-javafx/src/JavaFxDispatcher.kt +++ b/ui/kotlinx-coroutines-javafx/src/JavaFxDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.javafx import javafx.animation.* diff --git a/ui/kotlinx-coroutines-javafx/test/JavaFxDispatcherTest.kt b/ui/kotlinx-coroutines-javafx/test/JavaFxDispatcherTest.kt index 46f6a0249a..b3fabaa68b 100644 --- a/ui/kotlinx-coroutines-javafx/test/JavaFxDispatcherTest.kt +++ b/ui/kotlinx-coroutines-javafx/test/JavaFxDispatcherTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.javafx import javafx.application.* diff --git a/ui/kotlinx-coroutines-javafx/test/examples/FxExampleApp.kt b/ui/kotlinx-coroutines-javafx/test/examples/FxExampleApp.kt index f2b7fe066b..6ef81d648d 100644 --- a/ui/kotlinx-coroutines-javafx/test/examples/FxExampleApp.kt +++ b/ui/kotlinx-coroutines-javafx/test/examples/FxExampleApp.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package examples import javafx.application.* diff --git a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-actor-01.kt b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-actor-01.kt index d02a77a299..2d10632a24 100644 --- a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-actor-01.kt +++ b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-actor-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-guide-ui.md by Knit tool. Do not edit. package kotlinx.coroutines.javafx.guide.exampleUiActor01 diff --git a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-actor-02.kt b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-actor-02.kt index ec8a09f9bd..ba78af3354 100644 --- a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-actor-02.kt +++ b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-actor-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-guide-ui.md by Knit tool. Do not edit. package kotlinx.coroutines.javafx.guide.exampleUiActor02 diff --git a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-actor-03.kt b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-actor-03.kt index aa152b7937..9e7a16d816 100644 --- a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-actor-03.kt +++ b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-actor-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-guide-ui.md by Knit tool. Do not edit. package kotlinx.coroutines.javafx.guide.exampleUiActor03 diff --git a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-advanced-01.kt b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-advanced-01.kt index 06e439ef01..12271c2583 100644 --- a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-advanced-01.kt +++ b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-advanced-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-guide-ui.md by Knit tool. Do not edit. package kotlinx.coroutines.javafx.guide.exampleUiAdvanced01 diff --git a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-advanced-02.kt b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-advanced-02.kt index a3f89fcf94..cdd29db9ab 100644 --- a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-advanced-02.kt +++ b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-advanced-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-guide-ui.md by Knit tool. Do not edit. package kotlinx.coroutines.javafx.guide.exampleUiAdvanced02 diff --git a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-basic-01.kt b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-basic-01.kt index f54be59fc9..8390e7a825 100644 --- a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-basic-01.kt +++ b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-basic-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-guide-ui.md by Knit tool. Do not edit. package kotlinx.coroutines.javafx.guide.exampleUiBasic01 diff --git a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-basic-02.kt b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-basic-02.kt index 42751c4de5..9b8a3763b2 100644 --- a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-basic-02.kt +++ b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-basic-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-guide-ui.md by Knit tool. Do not edit. package kotlinx.coroutines.javafx.guide.exampleUiBasic02 diff --git a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-basic-03.kt b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-basic-03.kt index dd778cecef..653fb3fde0 100644 --- a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-basic-03.kt +++ b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-basic-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-guide-ui.md by Knit tool. Do not edit. package kotlinx.coroutines.javafx.guide.exampleUiBasic03 diff --git a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-blocking-01.kt b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-blocking-01.kt index 0c89ea70f7..7937fbbb40 100644 --- a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-blocking-01.kt +++ b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-blocking-01.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-guide-ui.md by Knit tool. Do not edit. package kotlinx.coroutines.javafx.guide.exampleUiBlocking01 diff --git a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-blocking-02.kt b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-blocking-02.kt index 6e8b984a20..a6b884ed8c 100644 --- a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-blocking-02.kt +++ b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-blocking-02.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-guide-ui.md by Knit tool. Do not edit. package kotlinx.coroutines.javafx.guide.exampleUiBlocking02 diff --git a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-blocking-03.kt b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-blocking-03.kt index 3ff5d7d5d0..802c0888b2 100644 --- a/ui/kotlinx-coroutines-javafx/test/guide/example-ui-blocking-03.kt +++ b/ui/kotlinx-coroutines-javafx/test/guide/example-ui-blocking-03.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - // This file was automatically generated from coroutines-guide-ui.md by Knit tool. Do not edit. package kotlinx.coroutines.javafx.guide.exampleUiBlocking03 diff --git a/ui/kotlinx-coroutines-swing/build.gradle.kts b/ui/kotlinx-coroutines-swing/build.gradle.kts index 157ce401b2..b801b37691 100644 --- a/ui/kotlinx-coroutines-swing/build.gradle.kts +++ b/ui/kotlinx-coroutines-swing/build.gradle.kts @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - dependencies { testImplementation(project(":kotlinx-coroutines-jdk8")) } diff --git a/ui/kotlinx-coroutines-swing/src/SwingDispatcher.kt b/ui/kotlinx-coroutines-swing/src/SwingDispatcher.kt index 010f18c6c2..aa378be12d 100644 --- a/ui/kotlinx-coroutines-swing/src/SwingDispatcher.kt +++ b/ui/kotlinx-coroutines-swing/src/SwingDispatcher.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2021 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.swing import kotlinx.coroutines.* diff --git a/ui/kotlinx-coroutines-swing/test/SwingTest.kt b/ui/kotlinx-coroutines-swing/test/SwingTest.kt index 6d5111ebec..dcf33bfa80 100644 --- a/ui/kotlinx-coroutines-swing/test/SwingTest.kt +++ b/ui/kotlinx-coroutines-swing/test/SwingTest.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2020 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package kotlinx.coroutines.swing import kotlinx.coroutines.* diff --git a/ui/kotlinx-coroutines-swing/test/examples/SwingExampleApp.kt b/ui/kotlinx-coroutines-swing/test/examples/SwingExampleApp.kt index 7c396bf95e..6fab58f106 100644 --- a/ui/kotlinx-coroutines-swing/test/examples/SwingExampleApp.kt +++ b/ui/kotlinx-coroutines-swing/test/examples/SwingExampleApp.kt @@ -1,7 +1,3 @@ -/* - * Copyright 2016-2018 JetBrains s.r.o. Use of this source code is governed by the Apache 2.0 license. - */ - package examples import kotlinx.coroutines.* From 5527c7e13086ae7e052e8d4b77cc7d341309ac8e Mon Sep 17 00:00:00 2001 From: Dmitry Khalanskiy Date: Thu, 18 Jan 2024 15:30:54 +0100 Subject: [PATCH 2/3] Undo the changes to LICENSE.txt --- LICENSE.txt | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/LICENSE.txt b/LICENSE.txt index 9477ff6795..9c308d958b 100644 --- a/LICENSE.txt +++ b/LICENSE.txt @@ -187,7 +187,7 @@ same "printed page" as the copyright notice for easier identification within third-party archives. - Copyright 2016-2024 JetBrains s.r.o. and Kotlin Programming Language contributors. + Copyright 2000-2020 JetBrains s.r.o. and Kotlin Programming Language contributors. Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with the License. From d0b6f4c62ed27a6f3485bd1017a4b159085b5d49 Mon Sep 17 00:00:00 2001 From: Dmitry Khalanskiy Date: Mon, 22 Jan 2024 13:10:12 +0100 Subject: [PATCH 3/3] Update the DebugProbesKt.bin to account for line number change We check a classfile to match verbatim to make sure it doesn't change unexpectedly, and removing the copyright triggered the check, as the line numbers of the functions (which are compiled into the classfile) changed. --- .../jvm/resources/DebugProbesKt.bin | Bin 1738 -> 1738 bytes 1 file changed, 0 insertions(+), 0 deletions(-) diff --git a/kotlinx-coroutines-core/jvm/resources/DebugProbesKt.bin b/kotlinx-coroutines-core/jvm/resources/DebugProbesKt.bin index 950dcf45bea0ec57b640ad8c5e4b7537fc13813a..ce82c796c19402f901393515be002540040b678c 100644 GIT binary patch delta 29 jcmX@bdy02M7b_$C