7dbdf1df8841c74b5e7c806e84bc3377b55b48e6
Files Diff
- Added: 2
- Removed: 2
- Renamed: 0
- Modified: 69
Refactorings reported:
Refactoring Name | Occurences | ||
---|---|---|---|
Pull Up Attribute | 3 | ||
Pull Up Attribute private usedBytes : long from class com.facebook.presto.memory.context.AbstractAggregatedMemoryContext to private usedBytes : long from class com.facebook.presto.memory.context.AggregatedMemoryContext | From | To | |
Pull Up Attribute private closed : boolean from class com.facebook.presto.memory.context.AbstractAggregatedMemoryContext to private closed : boolean from class com.facebook.presto.memory.context.AggregatedMemoryContext | From | To | |
Pull Up Attribute package NOT_BLOCKED : ListenableFuture<?> from class com.facebook.presto.memory.context.AbstractAggregatedMemoryContext to package NOT_BLOCKED : ListenableFuture<?> from class com.facebook.presto.memory.context.AggregatedMemoryContext | From | To | |
Rename Class | 1 | ||
Rename Class com.facebook.presto.operator.OperatorContext.InternalLocalMemoryContext renamed to com.facebook.presto.operator.OperatorContext.DecoratedLocalMemoryContext | From | To | |
Merge Variable | 1 | ||
Merge Variable [deltaUserMemoryInBytes : long, deltaTotalMemoryInBytes : long] to deltaMemoryInBytes : long in method private updateMemoryUsage(taskStatus TaskStatus) : void in class com.facebook.presto.execution.SqlStageExecution.StageTaskListener | From | To | |
Change Variable Type | 2 | ||
Change Variable Type parent : AbstractAggregatedMemoryContext to parent : AggregatedMemoryContext in method public transferMemory(to LocalMemoryContext) : void in class com.facebook.presto.memory.context.SimpleLocalMemoryContext | From | To | |
Change Variable Type parent : AbstractAggregatedMemoryContext to parent : AggregatedMemoryContext in method private checkMemoryContextState(target SimpleLocalMemoryContext) : void in class com.facebook.presto.memory.context.SimpleLocalMemoryContext | From | To | |
Extract Method | 1 | ||
Extract Method private createDriverContext(memoryLimit long, systemMemoryLimit long) : DriverContext extracted from private createDriverContext(memoryLimit long) : DriverContext in class com.facebook.presto.operator.TestHashAggregationOperator | From | To | |
Inline Variable | 1 | ||
Inline Variable taskUserMemory : long in method public getStageInfo(taskInfosSupplier Supplier<Iterable<TaskInfo>>, subStageInfosSupplier Supplier<Iterable<StageInfo>>) : StageInfo from class com.facebook.presto.execution.StageStateMachine | From | To | |
Rename Method | 4 | ||
Rename Method package getQueryMemoryReservation(queryId QueryId) : long renamed to package getQueryUserMemoryReservation(queryId QueryId) : long in class com.facebook.presto.memory.MemoryPool | From | To | |
Rename Method public getBufferBlockedFuture() : ListenableFuture<?> renamed to public getNotFullFuture() : ListenableFuture<?> in class com.facebook.presto.execution.buffer.OutputBufferMemoryManager | From | To | |
Rename Method public getTotalMemoryReservation() : long renamed to public getUserMemoryReservation() : long in class com.facebook.presto.memory.LowMemoryKiller.QueryMemoryInfo | From | To | |
Rename Method public exceededLocalUserMemoryLimit(maxMemory DataSize) : ExceededMemoryLimitException renamed to public exceededLocalLimit(maxMemory DataSize) : ExceededMemoryLimitException in class com.facebook.presto.ExceededMemoryLimitException | From | To | |
Pull Up Method | 6 | ||
Pull Up Method package addExact(usedBytes long, bytes long) : long from class com.facebook.presto.memory.context.AbstractAggregatedMemoryContext to package addExact(usedBytes long, bytes long) : long from class com.facebook.presto.memory.context.AggregatedMemoryContext | From | To | |
Pull Up Method public close() : void from class com.facebook.presto.memory.context.AbstractAggregatedMemoryContext to public close() : void from class com.facebook.presto.memory.context.AggregatedMemoryContext | From | To | |
Pull Up Method public toString() : String from class com.facebook.presto.memory.context.AbstractAggregatedMemoryContext to public toString() : String from class com.facebook.presto.memory.context.AggregatedMemoryContext | From | To | |
Pull Up Method package addBytes(bytes long) : void from class com.facebook.presto.memory.context.AbstractAggregatedMemoryContext to package addBytes(bytes long) : void from class com.facebook.presto.memory.context.AggregatedMemoryContext | From | To | |
Pull Up Method public getBytes() : long from class com.facebook.presto.memory.context.AbstractAggregatedMemoryContext to public getBytes() : long from class com.facebook.presto.memory.context.AggregatedMemoryContext | From | To | |
Pull Up Method public newLocalMemoryContext() : LocalMemoryContext from class com.facebook.presto.memory.context.AbstractAggregatedMemoryContext to public newLocalMemoryContext() : LocalMemoryContext from class com.facebook.presto.memory.context.AggregatedMemoryContext | From | To | |
Rename Variable | 3 | ||
Rename Variable currentUserMemory : long to currentMemory : long in method private updateMemoryUsage(taskStatus TaskStatus) : void in class com.facebook.presto.execution.SqlStageExecution.StageTaskListener | From | To | |
Rename Variable maxQueryUserMemoryPerNode : DataSize to maxQueryMemoryPerNode : DataSize in method public SqlTaskManager(planner LocalExecutionPlanner, locationFactory LocationFactory, taskExecutor TaskExecutor, queryMonitor QueryMonitor, nodeInfo NodeInfo, localMemoryManager LocalMemoryManager, taskManagementExecutor TaskManagementExecutor, config TaskManagerConfig, nodeMemoryConfig NodeMemoryConfig, localSpillManager LocalSpillManager, nodeSpillConfig NodeSpillConfig, gcMonitor GcMonitor) in class com.facebook.presto.execution.SqlTaskManager | From | To | |
Rename Variable availableMemory : long to maxHeap : long in method public LocalMemoryManager(config NodeMemoryConfig, systemMemoryConfig ReservedSystemMemoryConfig) in class com.facebook.presto.memory.LocalMemoryManager | From | To | |
Change Return Type | 3 | ||
Change Return Type AbstractAggregatedMemoryContext to AggregatedMemoryContext in method package getParent() : AggregatedMemoryContext in class com.facebook.presto.memory.context.ChildAggregatedMemoryContext | From | To | |
Change Return Type AbstractAggregatedMemoryContext to AggregatedMemoryContext in method package getParent() : AggregatedMemoryContext in class com.facebook.presto.memory.context.RootAggregatedMemoryContext | From | To | |
Change Return Type AbstractAggregatedMemoryContext to AggregatedMemoryContext in method package getParent() : AggregatedMemoryContext in class com.facebook.presto.memory.context.SimpleAggregatedMemoryContext | From | To | |
Rename Attribute | 5 | ||
Rename Attribute maxUserMemory : long to maxMemory : long in class com.facebook.presto.memory.QueryContext | From | To | |
Rename Attribute totalMemoryReservation : long to memoryReservation : long in class com.facebook.presto.memory.LowMemoryKiller.QueryMemoryInfo | From | To | |
Rename Attribute previousUserMemory : long to previousMemory : long in class com.facebook.presto.execution.SqlStageExecution.StageTaskListener | From | To | |
Rename Attribute bufferBlockedFuture : SettableFuture<?> to notFull : SettableFuture<?> in class com.facebook.presto.execution.buffer.OutputBufferMemoryManager | From | To | |
Rename Attribute memoryPool : MemoryPool to userPool : MemoryPool in class com.facebook.presto.memory.TestMemoryTracking | From | To | |
Change Attribute Type | 2 | ||
Change Attribute Type parentMemoryContext : AbstractAggregatedMemoryContext to parentMemoryContext : AggregatedMemoryContext in class com.facebook.presto.memory.context.ChildAggregatedMemoryContext | From | To | |
Change Attribute Type parentMemoryContext : AbstractAggregatedMemoryContext to parentMemoryContext : AggregatedMemoryContext in class com.facebook.presto.memory.context.SimpleLocalMemoryContext | From | To | |
Rename Parameter | 4 | ||
Rename Parameter expectedPoolMemory : long to expectedUserPoolMemory : long in method private assertLocalMemoryAllocations(memoryTrackingContext MemoryTrackingContext, expectedUserPoolMemory long, expectedContextUserMemory long, expectedSystemPoolMemory long, expectedContextSystemMemory long) : void in class com.facebook.presto.memory.TestMemoryTracking | From | To | |
Rename Parameter totalMemoryReservation : long to memoryReservation : long in method public QueryMemoryInfo(queryId QueryId, memoryPoolId MemoryPoolId, memoryReservation long) in class com.facebook.presto.memory.LowMemoryKiller.QueryMemoryInfo | From | To | |
Rename Parameter maxUserMemory : DataSize to maxMemory : DataSize in method public QueryContext(queryId QueryId, maxMemory DataSize, memoryPool MemoryPool, systemMemoryPool MemoryPool, gcMonitor GcMonitor, notificationExecutor Executor, yieldExecutor ScheduledExecutorService, maxSpill DataSize, spillSpaceTracker SpillSpaceTracker) in class com.facebook.presto.memory.QueryContext | From | To | |
Rename Parameter memoryLimit : long to systemMemoryLimit : long in method private createDriverContext(systemMemoryLimit long) : DriverContext in class com.facebook.presto.operator.TestHashAggregationOperator | From | To |