|
Rename Method private createMockTask(lock Object) : StreamTask<?,?> renamed to private createMockTaskWithTimer(timerService ProcessingTimeService) : StreamTask<?,?> in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Rename Method private createMockTask(lock Object) : StreamTask<?,?> renamed to private createMockTaskWithTimer(timerService ProcessingTimeService) : StreamTask<?,?> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Rename Method public getTimeServiceProvider() : TimeServiceProvider renamed to public getProcessingTimeService() : ProcessingTimeService in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext |
From |
To |
|
Rename Method protected getTimerService() : TimeServiceProvider renamed to protected getProcessingTimeService() : ProcessingTimeService in class org.apache.flink.streaming.api.operators.AbstractStreamOperator |
From |
To |
|
Rename Method public setTimeService(timeProvider TimeServiceProvider) : void renamed to public setProcessingTimeService(timeProvider ProcessingTimeService) : void in class org.apache.flink.streaming.runtime.tasks.StreamTask |
From |
To |
|
Rename Method public getTimeServiceProvider() : TimeServiceProvider renamed to public getProcessingTimeService() : ProcessingTimeService in class org.apache.flink.streaming.connectors.kafka.testutils.MockRuntimeContext |
From |
To |
|
Rename Method public getTimerService() : TimeServiceProvider renamed to public getProcessingTimeService() : ProcessingTimeService in class org.apache.flink.streaming.runtime.tasks.StreamTask |
From |
To |
|
Rename Method public getTimerService() : TimeServiceProvider renamed to public getProcessingTimeService() : ProcessingTimeService in class org.apache.flink.streaming.runtime.tasks.StreamTaskTestHarness |
From |
To |
|
Change Parameter Type lock : Object to timerService : ProcessingTimeService in method private createMockTaskWithTimer(timerService ProcessingTimeService) : StreamTask<?,?> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Parameter Type timers : TimeServiceProvider to timers : ProcessingTimeService in method private shutdownTimerServiceAndWait(timers ProcessingTimeService) : void in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Parameter Type testTimeProvider : TimeServiceProvider to processingTimeService : ProcessingTimeService in method public OneInputStreamOperatorTestHarness(operator OneInputStreamOperator<IN,OUT>, executionConfig ExecutionConfig, checkpointLock Object, processingTimeService ProcessingTimeService) in class org.apache.flink.streaming.util.OneInputStreamOperatorTestHarness |
From |
To |
|
Change Parameter Type timers : TimeServiceProvider to timers : ProcessingTimeService in method private shutdownTimerServiceAndWait(timers ProcessingTimeService) : void in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Parameter Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method package PeriodicWatermarkEmitter(allPartitions KafkaTopicPartitionStateWithPeriodicWatermarks<?,?>[], emitter SourceContext<?>, timerService ProcessingTimeService, autoWatermarkInterval long) in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher.PeriodicWatermarkEmitter |
From |
To |
|
Change Parameter Type lock : Object to timerService : ProcessingTimeService in method private createMockTaskWithTimer(timerService ProcessingTimeService) : StreamTask<?,?> in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Parameter Type timeService : TimeServiceProvider to timeService : ProcessingTimeService in method private AutomaticWatermarkContext(timeService ProcessingTimeService, checkpointLock Object, output Output<StreamRecord<T>>, watermarkInterval long) in class org.apache.flink.streaming.api.operators.StreamSourceContexts.AutomaticWatermarkContext |
From |
To |
|
Change Parameter Type timeService : TimeServiceProvider to timeService : ProcessingTimeService in method private WatermarkEmittingTask(timeService ProcessingTimeService, checkpointLock Object, output Output<StreamRecord<T>>) in class org.apache.flink.streaming.api.operators.StreamSourceContexts.AutomaticWatermarkContext.WatermarkEmittingTask |
From |
To |
|
Change Parameter Type timeService : TimeServiceProvider to processingTimeService : ProcessingTimeService in method public getSourceContext(timeCharacteristic TimeCharacteristic, processingTimeService ProcessingTimeService, checkpointLock Object, output Output<StreamRecord<OUT>>, watermarkInterval long) : SourceFunction.SourceContext<OUT> in class org.apache.flink.streaming.api.operators.StreamSourceContexts |
From |
To |
|
Change Parameter Type timeServiceProvider : TimeServiceProvider to timeServiceProvider : ProcessingTimeService in method public MockRuntimeContext(numberOfParallelSubtasks int, indexOfThisSubtask int, execConfig ExecutionConfig, timeServiceProvider ProcessingTimeService) in class org.apache.flink.streaming.connectors.kafka.testutils.MockRuntimeContext |
From |
To |
|
Change Parameter Type timeProvider : TimeServiceProvider to timeProvider : ProcessingTimeService in method private setupSourceOperator(operator StreamSource<T,?>, timeChar TimeCharacteristic, watermarkInterval long, latencyMarkInterval long, timeProvider ProcessingTimeService) : void in class org.apache.flink.streaming.runtime.operators.StreamSourceOperatorTest |
From |
To |
|
Change Parameter Type timeProvider : TimeServiceProvider to timeProvider : ProcessingTimeService in method public setProcessingTimeService(timeProvider ProcessingTimeService) : void in class org.apache.flink.streaming.runtime.tasks.StreamTask |
From |
To |
|
Change Parameter Type testTimeProvider : TestTimeServiceProvider to testTimeProvider : ProcessingTimeService in method public KeyedOneInputStreamOperatorTestHarness(operator OneInputStreamOperator<IN,OUT>, executionConfig ExecutionConfig, testTimeProvider ProcessingTimeService, keySelector KeySelector<IN,K>, keyType TypeInformation<K>) in class org.apache.flink.streaming.util.KeyedOneInputStreamOperatorTestHarness |
From |
To |
|
Change Parameter Type testTimeProvider : TestTimeServiceProvider to processingTimeService : ProcessingTimeService in method public OneInputStreamOperatorTestHarness(operator OneInputStreamOperator<IN,OUT>, executionConfig ExecutionConfig, processingTimeService ProcessingTimeService) in class org.apache.flink.streaming.util.OneInputStreamOperatorTestHarness |
From |
To |
|
Change Variable Type timerService : TestTimeServiceProvider to timerService : TestProcessingTimeService in method public testKeyValueStateInWindowFunction() : void in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method public testTumblingWindowSingleElements() : void in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timeServiceProvider : TestTimeServiceProvider to timeServiceProvider : TestProcessingTimeService in method public testFileReadingOperatorWithIngestionTime() : void in class org.apache.flink.hdfstests.ContinuousFileMonitoringTest |
From |
To |
|
Change Variable Type timerService : TestTimeServiceProvider to timerService : TestProcessingTimeService in method public checkpointRestoreWithPendingWindowSliding() : void in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timer : DefaultTimeServiceProvider to timer : SystemProcessingTimeService in method public testTriggerHoldsLock() : void in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeServiceTest |
From |
To |
|
Change Variable Type timer : DefaultTimeServiceProvider to timer : SystemProcessingTimeService in method public testImmediateShutdown() : void in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeServiceTest |
From |
To |
|
Change Variable Type timer : DefaultTimeServiceProvider to timer : SystemProcessingTimeService in method public testFutureCancellation() : void in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeServiceTest |
From |
To |
|
Change Variable Type timerService : TestTimeServiceProvider to timerService : TestProcessingTimeService in method public testKeyValueStateInWindowFunctionTumbling() : void in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method public testSlidingWindow() : void in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method public testTumblingWindow() : void in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timerService : TestTimeServiceProvider to timerService : TestProcessingTimeService in method public checkpointRestoreWithPendingWindowTumbling() : void in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method public testWindowTriggerTimeAlignment() : void in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timeServiceProvider : TimeServiceProvider to timeServiceProvider : ProcessingTimeService in method public testExceptionReporting() : void in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeServiceTest |
From |
To |
|
Change Variable Type timer : DefaultTimeServiceProvider to timer : SystemProcessingTimeService in method public testTimerSorting() : void in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeServiceTest |
From |
To |
|
Change Variable Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method public testTumblingWindowUniqueElements() : void in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method public testWindowTriggerTimeAlignment() : void in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method public testSlidingWindowSingleElements() : void in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method public testTumblingWindowDuplicateElements() : void in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type testTimeProvider : TestTimeServiceProvider to testTimeProvider : TestProcessingTimeService in method public testProcessingTimeSessionWindows() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorTest |
From |
To |
|
Change Variable Type testTimeProvider : TestTimeServiceProvider to testTimeProvider : TestProcessingTimeService in method public testProcessingTimeSlidingWindows() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorTest |
From |
To |
|
Change Variable Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method public testPropagateExceptionsFromProcessElement() : void in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timerService : TestTimeServiceProvider to timerService : TestProcessingTimeService in method public testKeyValueStateInWindowFunctionSliding() : void in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timeProvider : TestTimeServiceProvider to processingTimeService : TestProcessingTimeService in method public testAutomaticWatermarkContext() : void in class org.apache.flink.streaming.runtime.operators.StreamSourceOperatorTest |
From |
To |
|
Change Variable Type timeService : TimeServiceProvider to timeService : ProcessingTimeService in method public checkScheduledTimestampe() : void in class org.apache.flink.streaming.runtime.operators.StreamTaskTimerTest |
From |
To |
|
Change Variable Type timer : DefaultTimeServiceProvider to timer : SystemProcessingTimeService in method public testQuiescing() : void in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeServiceTest |
From |
To |
|
Change Variable Type timerService : TestTimeServiceProvider to timerService : TestProcessingTimeService in method public checkpointRestoreWithPendingWindowSliding() : void in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type testTimeProvider : TestTimeServiceProvider to testTimeProvider : TestProcessingTimeService in method public testProcessingTimeTumblingWindows() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorTest |
From |
To |
|
Change Variable Type tp : TestTimeServiceProvider to tp : TestProcessingTimeService in method public testCustomTimeServiceProvider() : void in class org.apache.flink.streaming.runtime.operators.TestProcessingTimeServiceTest |
From |
To |
|
Change Variable Type timerService : TestTimeServiceProvider to timerService : TestProcessingTimeService in method public checkpointRestoreWithPendingWindowTumbling() : void in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method public testSlidingWindow() : void in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method public testPeriodicWatermarks() : void in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcherTimestampsTest |
From |
To |
|
Change Variable Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in method public testSlidingWindowSingleElements() : void in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Attribute Type timeService : TimeServiceProvider to timeService : ProcessingTimeService in class org.apache.flink.streaming.api.operators.StreamSourceContexts.AutomaticWatermarkContext.WatermarkEmittingTask |
From |
To |
|
Change Attribute Type timeServiceProvider : TimeServiceProvider to processingTimeService : ProcessingTimeService in class org.apache.flink.streaming.util.OneInputStreamOperatorTestHarness |
From |
To |
|
Change Attribute Type timeServiceProvider : TimeServiceProvider to timeServiceProvider : ProcessingTimeService in class org.apache.flink.streaming.connectors.kafka.testutils.MockRuntimeContext |
From |
To |
|
Change Attribute Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher.PeriodicWatermarkEmitter |
From |
To |
|
Change Attribute Type timeServiceProvider : TestTimeServiceProvider to timeServiceProvider : TestProcessingTimeService in class org.apache.flink.streaming.util.WindowingTestHarness |
From |
To |
|
Change Attribute Type timeService : TimeServiceProvider to timeService : ProcessingTimeService in class org.apache.flink.streaming.api.operators.StreamSourceContexts.AutomaticWatermarkContext |
From |
To |
|
Change Attribute Type processingTimeService : TimeServiceProvider to processingTimeService : ProcessingTimeService in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink |
From |
To |
|
Change Attribute Type timerService : TimeServiceProvider to timerService : ProcessingTimeService in class org.apache.flink.streaming.runtime.tasks.StreamTask |
From |
To |
|
Rename Parameter lock : Object to timerService : ProcessingTimeService in method private createMockTaskWithTimer(timerService ProcessingTimeService) : StreamTask<?,?> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Rename Parameter testTimeProvider : TestTimeServiceProvider to processingTimeService : ProcessingTimeService in method public OneInputStreamOperatorTestHarness(operator OneInputStreamOperator<IN,OUT>, executionConfig ExecutionConfig, processingTimeService ProcessingTimeService) in class org.apache.flink.streaming.util.OneInputStreamOperatorTestHarness |
From |
To |
|
Rename Parameter lock : Object to timerService : ProcessingTimeService in method private createMockTaskWithTimer(timerService ProcessingTimeService) : StreamTask<?,?> in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Rename Parameter testTimeProvider : TimeServiceProvider to processingTimeService : ProcessingTimeService in method public OneInputStreamOperatorTestHarness(operator OneInputStreamOperator<IN,OUT>, executionConfig ExecutionConfig, checkpointLock Object, processingTimeService ProcessingTimeService) in class org.apache.flink.streaming.util.OneInputStreamOperatorTestHarness |
From |
To |
|
Rename Parameter timeService : TimeServiceProvider to processingTimeService : ProcessingTimeService in method public getSourceContext(timeCharacteristic TimeCharacteristic, processingTimeService ProcessingTimeService, checkpointLock Object, output Output<StreamRecord<OUT>>, watermarkInterval long) : SourceFunction.SourceContext<OUT> in class org.apache.flink.streaming.api.operators.StreamSourceContexts |
From |
To |