|
Pull Up Method public setResourceOvercommit() : void from class com.facebook.presto.memory.DefaultQueryContext to public setResourceOvercommit() : void from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method private getAdditionalFailureInfo(allocated long, delta long) : String from class com.facebook.presto.memory.DefaultQueryContext to private getAdditionalFailureInfo(allocated long, delta long) : String from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public reserveSpill(bytes long) : ListenableFuture<?> from class com.facebook.presto.memory.DefaultQueryContext to public reserveSpill(bytes long) : ListenableFuture<?> from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method private enforceUserMemoryLimit(allocated long, delta long, maxMemory long) : void from class com.facebook.presto.memory.LegacyQueryContext to private enforceUserMemoryLimit(allocated long, delta long, maxMemory long) : void from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public getMemoryPool() : MemoryPool from class com.facebook.presto.memory.LegacyQueryContext to public getMemoryPool() : MemoryPool from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method private enforceTotalMemoryLimit(allocated long, delta long, maxMemory long) : void from class com.facebook.presto.memory.DefaultQueryContext to private enforceTotalMemoryLimit(allocated long, delta long, maxMemory long) : void from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method package getQueryMemoryContext() : MemoryTrackingContext from class com.facebook.presto.memory.DefaultQueryContext to package getQueryMemoryContext() : MemoryTrackingContext from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public setMemoryPool(newMemoryPool MemoryPool) : void from class com.facebook.presto.memory.LegacyQueryContext to public setMemoryPool(newMemoryPool MemoryPool) : void from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public freeSpill(bytes long) : void from class com.facebook.presto.memory.DefaultQueryContext to public freeSpill(bytes long) : void from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method private tryReserveMemoryNotSupported(allocationTag String, bytes long) : boolean from class com.facebook.presto.memory.LegacyQueryContext to private tryReserveMemoryNotSupported(allocationTag String, bytes long) : boolean from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public accept(visitor QueryContextVisitor<C,R>, context C) : R from class com.facebook.presto.memory.DefaultQueryContext to public accept(visitor QueryContextVisitor<C,R>, context C) : R from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public freeSpill(bytes long) : void from class com.facebook.presto.memory.LegacyQueryContext to public freeSpill(bytes long) : void from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public accept(visitor QueryContextVisitor<C,R>, context C) : R from class com.facebook.presto.memory.LegacyQueryContext to public accept(visitor QueryContextVisitor<C,R>, context C) : R from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public getMemoryPool() : MemoryPool from class com.facebook.presto.memory.DefaultQueryContext to public getMemoryPool() : MemoryPool from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public acceptChildren(visitor QueryContextVisitor<C,R>, context C) : List<R> from class com.facebook.presto.memory.DefaultQueryContext to public acceptChildren(visitor QueryContextVisitor<C,R>, context C) : List<R> from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method private tryReserveMemoryNotSupported(allocationTag String, bytes long) : boolean from class com.facebook.presto.memory.DefaultQueryContext to private tryReserveMemoryNotSupported(allocationTag String, bytes long) : boolean from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public setMemoryPool(newMemoryPool MemoryPool) : void from class com.facebook.presto.memory.DefaultQueryContext to public setMemoryPool(newMemoryPool MemoryPool) : void from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public reserveSpill(bytes long) : ListenableFuture<?> from class com.facebook.presto.memory.LegacyQueryContext to public reserveSpill(bytes long) : ListenableFuture<?> from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public addTaskContext(taskStateMachine TaskStateMachine, session Session, perOperatorCpuTimerEnabled boolean, cpuTimerEnabled boolean, totalPartitions OptionalInt) : TaskContext from class com.facebook.presto.memory.DefaultQueryContext to public addTaskContext(taskStateMachine TaskStateMachine, session Session, perOperatorCpuTimerEnabled boolean, cpuTimerEnabled boolean, totalPartitions OptionalInt) : TaskContext from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method private updateRevocableMemory(allocationTag String, delta long) : ListenableFuture<?> from class com.facebook.presto.memory.LegacyQueryContext to private updateRevocableMemory(allocationTag String, delta long) : ListenableFuture<?> from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method private updateRevocableMemory(allocationTag String, delta long) : ListenableFuture<?> from class com.facebook.presto.memory.DefaultQueryContext to private updateRevocableMemory(allocationTag String, delta long) : ListenableFuture<?> from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method private updateSystemMemory(allocationTag String, delta long) : ListenableFuture<?> from class com.facebook.presto.memory.DefaultQueryContext to private updateSystemMemory(allocationTag String, delta long) : ListenableFuture<?> from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public getTaskContextByTaskId(taskId TaskId) : TaskContext from class com.facebook.presto.memory.LegacyQueryContext to public getTaskContextByTaskId(taskId TaskId) : TaskContext from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method private enforceUserMemoryLimit(allocated long, delta long, maxMemory long) : void from class com.facebook.presto.memory.DefaultQueryContext to private enforceUserMemoryLimit(allocated long, delta long, maxMemory long) : void from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method private updateUserMemory(allocationTag String, delta long) : ListenableFuture<?> from class com.facebook.presto.memory.DefaultQueryContext to private updateUserMemory(allocationTag String, delta long) : ListenableFuture<?> from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public addTaskContext(taskStateMachine TaskStateMachine, session Session, perOperatorCpuTimerEnabled boolean, cpuTimerEnabled boolean, totalPartitions OptionalInt) : TaskContext from class com.facebook.presto.memory.LegacyQueryContext to public addTaskContext(taskStateMachine TaskStateMachine, session Session, perOperatorCpuTimerEnabled boolean, cpuTimerEnabled boolean, totalPartitions OptionalInt) : TaskContext from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public acceptChildren(visitor QueryContextVisitor<C,R>, context C) : List<R> from class com.facebook.presto.memory.LegacyQueryContext to public acceptChildren(visitor QueryContextVisitor<C,R>, context C) : List<R> from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method private tryUpdateUserMemory(allocationTag String, delta long) : boolean from class com.facebook.presto.memory.DefaultQueryContext to private tryUpdateUserMemory(allocationTag String, delta long) : boolean from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method private getAdditionalFailureInfo(allocated long, delta long) : String from class com.facebook.presto.memory.LegacyQueryContext to private getAdditionalFailureInfo(allocated long, delta long) : String from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public getTaskContextByTaskId(taskId TaskId) : TaskContext from class com.facebook.presto.memory.DefaultQueryContext to public getTaskContextByTaskId(taskId TaskId) : TaskContext from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Method public DefaultQueryContext(queryId QueryId, maxUserMemory DataSize, maxTotalMemory DataSize, memoryPool MemoryPool, gcMonitor GcMonitor, notificationExecutor Executor, yieldExecutor ScheduledExecutorService, maxSpill DataSize, spillSpaceTracker SpillSpaceTracker) from class com.facebook.presto.memory.DefaultQueryContext to public QueryContext(queryId QueryId, maxUserMemory DataSize, maxTotalMemory DataSize, memoryPool MemoryPool, gcMonitor GcMonitor, notificationExecutor Executor, yieldExecutor ScheduledExecutorService, maxSpill DataSize, spillSpaceTracker SpillSpaceTracker) from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private queryId : QueryId from class com.facebook.presto.memory.DefaultQueryContext to private queryId : QueryId from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private queryMemoryContext : MemoryTrackingContext from class com.facebook.presto.memory.DefaultQueryContext to private queryMemoryContext : MemoryTrackingContext from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private spillUsed : long from class com.facebook.presto.memory.LegacyQueryContext to private spillUsed : long from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private maxSpill : long from class com.facebook.presto.memory.DefaultQueryContext to private maxSpill : long from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private GUARANTEED_MEMORY : long from class com.facebook.presto.memory.DefaultQueryContext to private GUARANTEED_MEMORY : long from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private notificationExecutor : Executor from class com.facebook.presto.memory.DefaultQueryContext to private notificationExecutor : Executor from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private maxUserMemory : long from class com.facebook.presto.memory.DefaultQueryContext to private maxUserMemory : long from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private taskContexts : Map<TaskId,TaskContext> from class com.facebook.presto.memory.DefaultQueryContext to private taskContexts : Map<TaskId,TaskContext> from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private taskContexts : Map<TaskId,TaskContext> from class com.facebook.presto.memory.LegacyQueryContext to private taskContexts : Map<TaskId,TaskContext> from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private memoryPool : MemoryPool from class com.facebook.presto.memory.DefaultQueryContext to private memoryPool : MemoryPool from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private gcMonitor : GcMonitor from class com.facebook.presto.memory.DefaultQueryContext to private gcMonitor : GcMonitor from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private spillUsed : long from class com.facebook.presto.memory.DefaultQueryContext to private spillUsed : long from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private spillSpaceTracker : SpillSpaceTracker from class com.facebook.presto.memory.DefaultQueryContext to private spillSpaceTracker : SpillSpaceTracker from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private maxTotalMemory : long from class com.facebook.presto.memory.DefaultQueryContext to private maxTotalMemory : long from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Pull Up Attribute private yieldExecutor : ScheduledExecutorService from class com.facebook.presto.memory.DefaultQueryContext to private yieldExecutor : ScheduledExecutorService from class com.facebook.presto.memory.QueryContext |
From |
To |
|
Change Variable Type queryContext : DefaultQueryContext to queryContext : QueryContext in method public build() : TaskContext in class com.facebook.presto.testing.TestingTaskContext.Builder |
From |
To |
|
Change Variable Type queryContext : DefaultQueryContext to queryContext : QueryContext in method public execute(query String) : List<Page> in class com.facebook.presto.benchmark.MemoryLocalQueryRunner |
From |
To |
|
Change Variable Type queryContext : DefaultQueryContext to queryContext : QueryContext in method private newTestingTaskContext(taskNotificationExecutor ScheduledExecutorService, driverYieldExecutor ScheduledExecutorService, taskStateMachine TaskStateMachine) : TaskContext in class com.facebook.presto.execution.TestSqlTaskExecution |
From |
To |
|
Change Variable Type queryContext : DefaultQueryContext to queryContext : QueryContext in method public createInitialTask() : SqlTask in class com.facebook.presto.execution.TestSqlTask |
From |
To |
|
Change Variable Type queryContext : DefaultQueryContext to queryContext : QueryContext in method public MockRemoteTask(taskId TaskId, fragment PlanFragment, nodeId String, executor Executor, scheduledExecutor ScheduledExecutorService, initialSplits Multimap<PlanNodeId,Split>, totalPartitions OptionalInt, partitionedSplitCountTracker PartitionedSplitCountTracker) in class com.facebook.presto.execution.MockRemoteTaskFactory.MockRemoteTask |
From |
To |
|
Change Variable Type queryContext : DefaultQueryContext to queryContext : QueryContext in method public testSetMemoryPool(useReservedPool boolean) : void in class com.facebook.presto.memory.TestQueryContext |
From |
To |
|
Change Variable Type queryContext : DefaultQueryContext to queryContext : QueryContext in method private setUp(driversSupplier Supplier<List<Driver>>) : void in class com.facebook.presto.memory.TestMemoryPools |
From |
To |
|
Change Variable Type queryContext : DefaultQueryContext to queryContext : QueryContext in method public finishOperatorWithYieldingGroupByHash(input List<Page>, hashKeyType Type, operatorFactory OperatorFactory, getHashCapacity Function<Operator,Integer>, additionalMemoryInBytes long) : GroupByHashYieldResult in class com.facebook.presto.operator.GroupByHashYieldAssertion |
From |
To |