|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected startClusterComponents(configuration Configuration, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, blobServer BlobServer, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl) : void in class org.apache.flink.mesos.entrypoint.MesosJobClusterEntrypoint |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected startResourceManagers(configuration Configuration, haServices HighAvailabilityServices, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, numResourceManagers int, resourceManagerRpcServices RpcService[]) : ResourceManagerRunner[] in class org.apache.flink.runtime.minicluster.MiniCluster |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public MiniClusterJobDispatcher(config Configuration, haServices HighAvailabilityServices, blobServer BlobServer, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, numJobManagers int, rpcServices RpcService[]) in class org.apache.flink.runtime.minicluster.MiniClusterJobDispatcher |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public TaskExecutor(rpcService RpcService, taskManagerConfiguration TaskManagerConfiguration, taskManagerLocation TaskManagerLocation, memoryManager MemoryManager, ioManager IOManager, networkEnvironment NetworkEnvironment, haServices HighAvailabilityServices, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, taskManagerMetricGroup TaskManagerMetricGroup, broadcastVariableManager BroadcastVariableManager, fileCache FileCache, taskSlotTable TaskSlotTable, jobManagerTable JobManagerTable, jobLeaderService JobLeaderService, fatalErrorHandler FatalErrorHandler) in class org.apache.flink.runtime.taskexecutor.TaskExecutor |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected startClusterComponents(configuration Configuration, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, blobServer BlobServer, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl) : void in class org.apache.flink.mesos.entrypoint.MesosSessionClusterEntrypoint |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected abstract createJobManagerRunner(resourceId ResourceID, jobGraph JobGraph, configuration Configuration, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, jobManagerServices JobManagerServices, metricRegistry MetricRegistryImpl, onCompleteActions OnCompletionActions, fatalErrorHandler FatalErrorHandler) : JobManagerRunner in class org.apache.flink.runtime.dispatcher.Dispatcher |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected createResourceManager(configuration Configuration, resourceId ResourceID, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, fatalErrorHandler FatalErrorHandler) : ResourceManager<?> in class org.apache.flink.mesos.entrypoint.MesosSessionClusterEntrypoint |
From |
To |
|
Change Parameter Type tmID : InstanceID to tmRID : ResourceID in method private createRequestDumpAnswer(tmRID ResourceID, jobID JobID) : MetricDumpSerialization.MetricSerializationResult in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcherTest |
From |
To |
|
Change Parameter Type instanceId : InstanceID to resourceId : ResourceID in method public requestTaskManagerInstance(resourceId ResourceID, timeout Time) : CompletableFuture<Optional<Instance>> in class org.apache.flink.runtime.akka.AkkaJobManagerGateway |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected createJobManagerRunner(resourceId ResourceID, jobGraph JobGraph, configuration Configuration, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, jobManagerServices JobManagerServices, metricRegistry MetricRegistryImpl, onCompleteActions OnCompletionActions, fatalErrorHandler FatalErrorHandler) : JobManagerRunner in class org.apache.flink.runtime.dispatcher.DispatcherTest.TestingDispatcher |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public MesosResourceManager(rpcService RpcService, resourceManagerEndpointId String, resourceId ResourceID, resourceManagerConfiguration ResourceManagerConfiguration, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, slotManager SlotManager, metricRegistry MetricRegistryImpl, jobLeaderIdService JobLeaderIdService, fatalErrorHandler FatalErrorHandler, flinkConfig Configuration, mesosServices MesosServices, mesosConfig MesosConfiguration, taskManagerParameters MesosTaskManagerParameters, taskManagerContainerSpec ContainerSpecification) in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected createResourceManager(configuration Configuration, resourceId ResourceID, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, fatalErrorHandler FatalErrorHandler) : ResourceManager<?> in class org.apache.flink.runtime.entrypoint.StandaloneSessionClusterEntrypoint |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected createResourceManager(configuration Configuration, resourceId ResourceID, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, fatalErrorHandler FatalErrorHandler) : ResourceManager<?> in class org.apache.flink.mesos.entrypoint.MesosJobClusterEntrypoint |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected TestingDispatcher(rpcService RpcService, endpointId String, configuration Configuration, highAvailabilityServices HighAvailabilityServices, resourceManagerGateway ResourceManagerGateway, blobServer BlobServer, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, fatalErrorHandler FatalErrorHandler, jobManagerRunner JobManagerRunner, expectedJobId JobID) in class org.apache.flink.runtime.dispatcher.DispatcherTest.TestingDispatcher |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public StandaloneResourceManager(rpcService RpcService, resourceManagerEndpointId String, resourceId ResourceID, resourceManagerConfiguration ResourceManagerConfiguration, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, slotManager SlotManager, metricRegistry MetricRegistryImpl, jobLeaderIdService JobLeaderIdService, fatalErrorHandler FatalErrorHandler) in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public YarnResourceManager(rpcService RpcService, resourceManagerEndpointId String, resourceId ResourceID, flinkConfig Configuration, env Map<String,String>, resourceManagerConfiguration ResourceManagerConfiguration, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, slotManager SlotManager, metricRegistry MetricRegistryImpl, jobLeaderIdService JobLeaderIdService, fatalErrorHandler FatalErrorHandler) in class org.apache.flink.yarn.YarnResourceManager |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected startClusterComponents(configuration Configuration, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, blobServer BlobServer, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl) : void in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public JobManagerRunner(resourceId ResourceID, jobGraph JobGraph, configuration Configuration, rpcService RpcService, haServices HighAvailabilityServices, heartbeatServices HeartbeatServices, jobManagerServices JobManagerServices, metricRegistry MetricRegistryImpl, toNotifyOnComplete OnCompletionActions, errorHandler FatalErrorHandler) in class org.apache.flink.runtime.jobmaster.JobManagerRunner |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected abstract startClusterComponents(configuration Configuration, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, blobServer BlobServer, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl) : void in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected startTaskManagers(configuration Configuration, haServices HighAvailabilityServices, metricRegistry MetricRegistryImpl, numTaskManagers int, taskManagerRpcServices RpcService[]) : TaskExecutor[] in class org.apache.flink.runtime.minicluster.MiniCluster |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected createJobManagerRunner(configuration Configuration, resourceId ResourceID, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, jobManagerServices JobManagerServices, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, fatalErrorHandler FatalErrorHandler) : JobManagerRunner in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected createResourceManager(configuration Configuration, resourceId ResourceID, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, fatalErrorHandler FatalErrorHandler) : ResourceManager<?> in class org.apache.flink.yarn.entrypoint.YarnJobClusterEntrypoint |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected abstract createResourceManager(configuration Configuration, resourceId ResourceID, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, fatalErrorHandler FatalErrorHandler) : ResourceManager<?> in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected createJobManagerRunner(resourceId ResourceID, jobGraph JobGraph, configuration Configuration, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, jobManagerServices JobManagerServices, metricRegistry MetricRegistryImpl, onCompleteActions OnCompletionActions, fatalErrorHandler FatalErrorHandler) : JobManagerRunner in class org.apache.flink.runtime.dispatcher.StandaloneDispatcher |
From |
To |
|
Change Parameter Type instanceId : InstanceID to resourceId : ResourceID in method public requestTaskManagerInstance(resourceId ResourceID, timeout Time) : CompletableFuture<Optional<Instance>> in class org.apache.flink.runtime.jobmaster.JobManagerGateway |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected Dispatcher(rpcService RpcService, endpointId String, configuration Configuration, highAvailabilityServices HighAvailabilityServices, resourceManagerGateway ResourceManagerGateway, blobServer BlobServer, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, fatalErrorHandler FatalErrorHandler, restAddress Optional<String>) in class org.apache.flink.runtime.dispatcher.Dispatcher |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public startTaskManager(configuration Configuration, resourceID ResourceID, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, localCommunicationOnly boolean, fatalErrorHandler FatalErrorHandler) : TaskExecutor in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public StandaloneDispatcher(rpcService RpcService, endpointId String, configuration Configuration, highAvailabilityServices HighAvailabilityServices, resourceManagerGateway ResourceManagerGateway, blobServer BlobServer, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, fatalErrorHandler FatalErrorHandler, restAddress Optional<String>) in class org.apache.flink.runtime.dispatcher.StandaloneDispatcher |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected createResourceManager(configuration Configuration, resourceId ResourceID, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, fatalErrorHandler FatalErrorHandler) : ResourceManager<?> in class org.apache.flink.yarn.entrypoint.YarnSessionClusterEntrypoint |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public TestingMesosResourceManager(rpcService RpcService, resourceManagerEndpointId String, resourceId ResourceID, resourceManagerConfiguration ResourceManagerConfiguration, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, slotManager SlotManager, metricRegistry MetricRegistryImpl, jobLeaderIdService JobLeaderIdService, fatalErrorHandler FatalErrorHandler, flinkConfig Configuration, mesosServices MesosServices, mesosConfig MesosConfiguration, taskManagerParameters MesosTaskManagerParameters, taskManagerContainerSpec ContainerSpecification) in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManagerTest.TestingMesosResourceManager |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public ResourceManagerRunner(resourceId ResourceID, resourceManagerEndpointId String, configuration Configuration, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl) in class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected startClusterComponents(configuration Configuration, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, blobServer BlobServer, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl) : void in class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected abstract createResourceManager(configuration Configuration, resourceId ResourceID, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, fatalErrorHandler FatalErrorHandler) : ResourceManager<?> in class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public MiniClusterJobDispatcher(config Configuration, rpcService RpcService, haServices HighAvailabilityServices, blobServer BlobServer, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl) in class org.apache.flink.runtime.minicluster.MiniClusterJobDispatcher |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method protected createDispatcher(configuration Configuration, rpcService RpcService, highAvailabilityServices HighAvailabilityServices, resourceManagerGateway ResourceManagerGateway, blobServer BlobServer, heartbeatServices HeartbeatServices, metricRegistry MetricRegistryImpl, fatalErrorHandler FatalErrorHandler, restAddress Optional<String>) : Dispatcher in class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint |
From |
To |
|
Change Parameter Type metricsRegistry : Option<MetricRegistry> to jobManagerMetricGroup : JobManagerMetricGroup in method public TestingFailingHAJobManager(flinkConfiguration Configuration, futureExecutor ScheduledExecutorService, ioExecutor Executor, instanceManager InstanceManager, scheduler Scheduler, blobServer BlobServer, libraryCacheManager BlobLibraryCacheManager, archive ActorRef, restartStrategyFactory RestartStrategyFactory, timeout FiniteDuration, leaderElectionService LeaderElectionService, submittedJobGraphs SubmittedJobGraphStore, checkpointRecoveryFactory CheckpointRecoveryFactory, jobRecoveryTimeout FiniteDuration, jobManagerMetricGroup JobManagerMetricGroup, recoveredJobs Collection<JobID>) in class org.apache.flink.runtime.jobmanager.JobManagerHARecoveryTest.TestingFailingHAJobManager |
From |
To |
|
Change Parameter Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public ResourceManager(rpcService RpcService, resourceManagerEndpointId String, resourceId ResourceID, resourceManagerConfiguration ResourceManagerConfiguration, highAvailabilityServices HighAvailabilityServices, heartbeatServices HeartbeatServices, slotManager SlotManager, metricRegistry MetricRegistryImpl, jobLeaderIdService JobLeaderIdService, fatalErrorHandler FatalErrorHandler) in class org.apache.flink.runtime.resourcemanager.ResourceManager |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testCloseClosesAll() : void in class org.apache.flink.runtime.metrics.groups.JobManagerGroupTest |
From |
To |
|
Change Variable Type instanceID : InstanceID to resourceId : ResourceID in method public handleJsonRequest(pathParams Map<String,String>, queryParams Map<String,String>, jobManagerGateway JobManagerGateway) : CompletableFuture<String> in class org.apache.flink.runtime.rest.handler.legacy.TaskManagersHandler |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testCreateDump() : void in class org.apache.flink.runtime.metrics.dump.MetricQueryServiceTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testQueryActorShutdown() : void in class org.apache.flink.runtime.metrics.MetricRegistryImplTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testExceptionIsolation() : void in class org.apache.flink.runtime.metrics.MetricRegistryImplTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testCreateQueryServiceMetricInfo() : void in class org.apache.flink.runtime.metrics.groups.JobManagerGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testCreateQueryServiceMetricInfo() : void in class org.apache.flink.runtime.metrics.groups.OperatorGroupTest |
From |
To |
|
Change Variable Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public testMultipleReporterInstantiation() : void in class org.apache.flink.runtime.metrics.MetricRegistryImplTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testVariables() : void in class org.apache.flink.runtime.metrics.groups.OperatorGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testHistogramReporting() : void in class org.apache.flink.metrics.jmx.JMXReporterTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testMetricInstantiation() : void in class org.apache.flink.runtime.metrics.groups.MetricGroupRegistrationTest |
From |
To |
|
Change Variable Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method private createAndStartResourceManager(resourceManagerLeaderElectionService LeaderElectionService, jobID JobID, jobMasterLeaderRetrievalService LeaderRetrievalService, fatalErrorHandler FatalErrorHandler) : ResourceManager in class org.apache.flink.runtime.resourcemanager.ResourceManagerJobMasterTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeWilcard() : void in class org.apache.flink.runtime.metrics.groups.TaskMetricGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testReporterScheduling() : void in class org.apache.flink.runtime.metrics.MetricRegistryImplTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public addAndRemoveJobs() : void in class org.apache.flink.runtime.metrics.groups.JobManagerGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeCustom() : void in class org.apache.flink.runtime.metrics.groups.JobManagerGroupTest |
From |
To |
|
Change Variable Type fixedPort2 : MetricRegistry to fixedPort2 : MetricRegistryImpl in method public cannotStartTwoReportersOnSamePort() : void in class org.apache.flink.metrics.prometheus.PrometheusReporterTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testCreateQueryServiceMetricInfo() : void in class org.apache.flink.runtime.metrics.groups.TaskMetricGroupTest |
From |
To |
|
Change Variable Type testRegistry : MetricRegistry to testRegistry : MetricRegistryImpl in method public testScopeCachingForMultipleReporters() : void in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeDefault() : void in class org.apache.flink.runtime.metrics.groups.JobManagerGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testConfigurableDelimiterForReporters() : void in class org.apache.flink.runtime.metrics.MetricRegistryImplTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testMeterReporting() : void in class org.apache.flink.metrics.jmx.JMXReporterTest |
From |
To |
|
Change Variable Type instanceID : InstanceID to resourceId : ResourceID in method protected respondAsLeader(ctx ChannelHandlerContext, routed Routed, jobManagerGateway JobManagerGateway) : void in class org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandler |
From |
To |
|
Change Variable Type testRegistry : MetricRegistry to testRegistry : MetricRegistryImpl in method public testScopeGenerationWithoutReporters() : void in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroupTest |
From |
To |
|
Change Variable Type portRange2 : MetricRegistry to portRange2 : MetricRegistryImpl in method public canStartTwoReportersWhenUsingPortRange() : void in class org.apache.flink.metrics.prometheus.PrometheusReporterTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testConfigurableDelimiterForReportersInGroup() : void in class org.apache.flink.runtime.metrics.MetricRegistryImplTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeCustomWildcard() : void in class org.apache.flink.runtime.metrics.groups.JobManagerJobGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeCustom() : void in class org.apache.flink.runtime.metrics.groups.TaskMetricGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testCreateQueryServiceMetricInfo() : void in class org.apache.flink.runtime.metrics.groups.JobManagerJobGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testDropwizardHistogramWrapperReporting() : void in class org.apache.flink.dropwizard.metrics.DropwizardFlinkHistogramWrapperTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeDefault() : void in class org.apache.flink.runtime.metrics.groups.TaskMetricGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testStatsDHistogramReporting() : void in class org.apache.flink.metrics.statsd.StatsDReporterTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testIOMetricGroupInstantiation() : void in class org.apache.flink.runtime.metrics.groups.OperatorGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeDefault() : void in class org.apache.flink.runtime.metrics.groups.OperatorGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testStatsDMetersReporting() : void in class org.apache.flink.metrics.statsd.StatsDReporterTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGetAllVariables() : void in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeCustom() : void in class org.apache.flink.runtime.metrics.groups.OperatorGroupTest |
From |
To |
|
Change Variable Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method private createAndStartResourceManager(rmLeaderElectionService LeaderElectionService, fatalErrorHandler FatalErrorHandler) : StandaloneResourceManager in class org.apache.flink.runtime.resourcemanager.ResourceManagerTaskExecutorTest |
From |
To |
|
Change Variable Type tmRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public testMetricRegistryLifeCycle() : void in class org.apache.flink.runtime.metrics.TaskManagerMetricsTest |
From |
To |
|
Change Variable Type portRange1 : MetricRegistry to portRange1 : MetricRegistryImpl in method public canStartTwoReportersWhenUsingPortRange() : void in class org.apache.flink.metrics.prometheus.PrometheusReporterTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testDuplicateGroupName() : void in class org.apache.flink.runtime.metrics.groups.MetricGroupRegistrationTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testReporterNotifications() : void in class org.apache.flink.runtime.metrics.MetricRegistryImplTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testOperatorNameTruncation() : void in class org.apache.flink.runtime.metrics.groups.TaskMetricGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeCustomWildcard() : void in class org.apache.flink.runtime.metrics.groups.TaskManagerJobGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public addAndRemoveJobs() : void in class org.apache.flink.runtime.metrics.groups.TaskManagerGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeCustom() : void in class org.apache.flink.runtime.metrics.groups.TaskManagerGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testCreateQueryServiceMetricInfo() : void in class org.apache.flink.runtime.metrics.groups.TaskManagerJobGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeCustom() : void in class org.apache.flink.runtime.metrics.groups.TaskManagerJobGroupTest |
From |
To |
|
Change Variable Type reg : MetricRegistry to reg : MetricRegistryImpl in method public testPortConflictHandling() : void in class org.apache.flink.metrics.jmx.JMXReporterTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testCloseClosesAll() : void in class org.apache.flink.runtime.metrics.groups.TaskManagerGroupTest |
From |
To |
|
Change Variable Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public testAddingMetrics() : void in class org.apache.flink.metrics.statsd.StatsDReporterTest |
From |
To |
|
Change Variable Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public testGrantAndRevokeLeadership() : void in class org.apache.flink.runtime.resourcemanager.ResourceManagerHATest |
From |
To |
|
Change Variable Type metricQueryServicePaths : ArrayList<Tuple2<InstanceID,String>> to metricQueryServicePaths : ArrayList<Tuple2<ResourceID,String>> in method public requestTaskManagerMetricQueryServicePaths(timeout Time) : CompletableFuture<Collection<Tuple2<ResourceID,String>>> in class org.apache.flink.runtime.resourcemanager.ResourceManager |
From |
To |
|
Change Variable Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public testHeartbeatTimeoutWithTaskExecutor() : void in class org.apache.flink.runtime.clusterframework.ResourceManagerTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeDefault() : void in class org.apache.flink.runtime.metrics.groups.JobManagerJobGroupTest |
From |
To |
|
Change Variable Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public testSlotAllocation() : void in class org.apache.flink.runtime.taskexecutor.TaskExecutorITCase |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeDefault() : void in class org.apache.flink.runtime.metrics.groups.TaskManagerGroupTest |
From |
To |
|
Change Variable Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public testHeartbeatTimeoutWithJobManager() : void in class org.apache.flink.runtime.clusterframework.ResourceManagerTest |
From |
To |
|
Change Variable Type taskManagerQueryServicePathsFuture : CompletableFuture<Collection<Tuple2<InstanceID,String>>> to taskManagerQueryServicePathsFuture : CompletableFuture<Collection<Tuple2<ResourceID,String>>> in method private fetchMetrics() : void in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcher |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testCreateQueryServiceMetricInfo() : void in class org.apache.flink.runtime.metrics.groups.MetricGroupTest |
From |
To |
|
Change Variable Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public testReporterInstantiation() : void in class org.apache.flink.runtime.metrics.MetricRegistryImplTest |
From |
To |
|
Change Variable Type fixedPort1 : MetricRegistry to fixedPort1 : MetricRegistryImpl in method public cannotStartTwoReportersOnSamePort() : void in class org.apache.flink.metrics.prometheus.PrometheusReporterTest |
From |
To |
|
Change Variable Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public testIsShutdown() : void in class org.apache.flink.runtime.metrics.MetricRegistryImplTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeDefault() : void in class org.apache.flink.runtime.metrics.groups.TaskManagerJobGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public endpointIsUnavailableAfterReporterIsClosed() : void in class org.apache.flink.metrics.prometheus.PrometheusReporterTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testCreateQueryServiceMetricInfo() : void in class org.apache.flink.runtime.metrics.groups.TaskManagerGroupTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testGenerateScopeCustom() : void in class org.apache.flink.runtime.metrics.groups.JobManagerJobGroupTest |
From |
To |
|
Change Variable Type metricRegistry : MetricRegistry to metricRegistry : MetricRegistryImpl in method public testAddingMetrics() : void in class org.apache.flink.dropwizard.ScheduledDropwizardReporterTest |
From |
To |
|
Change Variable Type reg : MetricRegistry to reg : MetricRegistryImpl in method public testJMXAvailability() : void in class org.apache.flink.metrics.jmx.JMXReporterTest |
From |
To |
|
Change Variable Type registry : MetricRegistry to registry : MetricRegistryImpl in method public testConfigurableDelimiter() : void in class org.apache.flink.runtime.metrics.MetricRegistryImplTest |
From |
To |