|
Change Parameter Type node : Node to node : InternalNode in method public assignBucketToNode(bucketedId int, node InternalNode) : void in class com.facebook.presto.execution.scheduler.group.DynamicBucketNodeMap |
From |
To |
|
Change Parameter Type newNode : Node to newNode : InternalNode in method public createTableScanTask(taskId TaskId, newNode InternalNode, splits List<Split>, partitionedSplitCountTracker PartitionedSplitCountTracker) : MockRemoteTask in class com.facebook.presto.execution.MockRemoteTaskFactory |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public scheduleSplits(node InternalNode, splits Multimap<PlanNodeId,Split>, noMoreSplitsNotification Multimap<PlanNodeId,Lifespan>) : Set<RemoteTask> in class com.facebook.presto.execution.SqlStageExecution |
From |
To |
|
Change Parameter Type nodesByHostAndPort : SetMultimap<HostAddress,Node> to nodesByHostAndPort : SetMultimap<HostAddress,InternalNode> in method public NodeMap(nodesByHostAndPort SetMultimap<HostAddress,InternalNode>, nodesByHost SetMultimap<InetAddress,InternalNode>, workersByNetworkPath SetMultimap<NetworkLocation,InternalNode>, coordinatorNodeIds Set<String>) in class com.facebook.presto.execution.scheduler.NodeMap |
From |
To |
|
Change Parameter Type excludedNodes : Set<Node> to excludedNodes : Set<InternalNode> in method public selectRandomNodes(limit int, excludedNodes Set<InternalNode>) : List<InternalNode> in class com.facebook.presto.execution.scheduler.NodeSelector |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public assignBucketToNode(bucketedId int, node InternalNode) : void in class com.facebook.presto.execution.scheduler.FixedBucketNodeMap |
From |
To |
|
Change Parameter Type assignments : Multimap<Node,Split> to assignments : Multimap<InternalNode,Split> in method public SplitPlacementResult(blocked ListenableFuture<?>, assignments Multimap<InternalNode,Split>) in class com.facebook.presto.execution.scheduler.SplitPlacementResult |
From |
To |
|
Change Parameter Type partitionToNode : List<Node> to partitionToNode : List<InternalNode> in method public FixedCountScheduler(taskScheduler TaskScheduler, partitionToNode List<InternalNode>) in class com.facebook.presto.execution.scheduler.FixedCountScheduler |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public createRemoteTask(session Session, taskId TaskId, node InternalNode, fragment PlanFragment, initialSplits Multimap<PlanNodeId,Split>, totalPartitions OptionalInt, outputBuffers OutputBuffers, partitionedSplitCountTracker PartitionedSplitCountTracker, summarizeTaskInfo boolean) : RemoteTask in class com.facebook.presto.server.remotetask.HttpRemoteTaskFactory |
From |
To |
|
Change Parameter Type partitionToNode : List<Node> to partitionToNode : List<InternalNode> in method public NodePartitionMap(partitionToNode List<InternalNode>, splitToBucket ToIntFunction<Split>) in class com.facebook.presto.sql.planner.NodePartitionMap |
From |
To |
|
Change Parameter Type noMoreSplitsNotification : Multimap<Node,Lifespan> to noMoreSplitsNotification : Multimap<InternalNode,Lifespan> in method private assignSplits(splitAssignment Multimap<InternalNode,Split>, noMoreSplitsNotification Multimap<InternalNode,Lifespan>) : Set<RemoteTask> in class com.facebook.presto.execution.scheduler.SourcePartitionedScheduler |
From |
To |
|
Change Parameter Type activeCoordinators : Set<Node> to activeCoordinators : Set<InternalNode> in method public AllNodes(activeNodes Set<InternalNode>, inactiveNodes Set<InternalNode>, shuttingDownNodes Set<InternalNode>, activeCoordinators Set<InternalNode>) in class com.facebook.presto.metadata.AllNodes |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public RemoteNodeMemory(node InternalNode, httpClient HttpClient, memoryInfoCodec Codec<MemoryInfo>, assignmentsRequestCodec Codec<MemoryPoolAssignmentsRequest>, memoryInfoUri URI, isBinaryTransportEnabled boolean) in class com.facebook.presto.memory.RemoteNodeMemory |
From |
To |
|
Change Parameter Type workersByNetworkPath : SetMultimap<NetworkLocation,Node> to workersByNetworkPath : SetMultimap<NetworkLocation,InternalNode> in method public NodeMap(nodesByHostAndPort SetMultimap<HostAddress,InternalNode>, nodesByHost SetMultimap<InetAddress,InternalNode>, workersByNetworkPath SetMultimap<NetworkLocation,InternalNode>, coordinatorNodeIds Set<String>) in class com.facebook.presto.execution.scheduler.NodeMap |
From |
To |
|
Change Parameter Type nodes : Iterable<Node> to nodes : Iterable<InternalNode> in method public addNode(connectorId ConnectorId, nodes Iterable<InternalNode>) : void in class com.facebook.presto.metadata.InMemoryNodeManager |
From |
To |
|
Change Parameter Type bucketToNode : List<Node> to bucketToNode : List<InternalNode> in method public FixedBucketNodeMap(splitToBucket ToIntFunction<Split>, bucketToNode List<InternalNode>) in class com.facebook.presto.execution.scheduler.FixedBucketNodeMap |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public createMemoryInfoLocation(node InternalNode) : URI in class com.facebook.presto.execution.LocationFactory |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method private createOrGetNodeTasks(node InternalNode) : NodeTasks in class com.facebook.presto.execution.NodeTaskMap |
From |
To |
|
Change Parameter Type inactiveNodes : Set<Node> to inactiveNodes : Set<InternalNode> in method public AllNodes(activeNodes Set<InternalNode>, inactiveNodes Set<InternalNode>, shuttingDownNodes Set<InternalNode>, activeCoordinators Set<InternalNode>) in class com.facebook.presto.metadata.AllNodes |
From |
To |
|
Change Parameter Type nodesByHost : SetMultimap<InetAddress,Node> to nodesByHost : SetMultimap<InetAddress,InternalNode> in method public NodeMap(nodesByHostAndPort SetMultimap<HostAddress,InternalNode>, nodesByHost SetMultimap<InetAddress,InternalNode>, workersByNetworkPath SetMultimap<NetworkLocation,InternalNode>, coordinatorNodeIds Set<String>) in class com.facebook.presto.execution.scheduler.NodeMap |
From |
To |
|
Change Parameter Type shuttingDownNodes : Set<Node> to shuttingDownNodes : Set<InternalNode> in method public AllNodes(activeNodes Set<InternalNode>, inactiveNodes Set<InternalNode>, shuttingDownNodes Set<InternalNode>, activeCoordinators Set<InternalNode>) in class com.facebook.presto.metadata.AllNodes |
From |
To |
|
Change Parameter Type allNodes : List<Node> to allNodes : List<InternalNode> in method public DynamicLifespanScheduler(bucketNodeMap BucketNodeMap, allNodes List<InternalNode>, partitionHandles List<ConnectorPartitionHandle>, concurrentLifespansPerTask OptionalInt) in class com.facebook.presto.execution.scheduler.group.DynamicLifespanScheduler |
From |
To |
|
Change Parameter Type excludedNodes : Set<Node> to excludedNodes : Set<InternalNode> in method public selectRandomNodes(limit int, excludedNodes Set<InternalNode>) : List<InternalNode> in class com.facebook.presto.execution.scheduler.SimpleNodeSelector |
From |
To |
|
Change Parameter Type inactiveNodes : Set<Node> to inactiveNodes : Set<InternalNode> in method private announceNodes(activeNodes Set<InternalNode>, inactiveNodes Set<InternalNode>) : void in class com.facebook.presto.metadata.TestDiscoveryNodeManager.PrestoNodeServiceSelector |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public createTaskLocation(node InternalNode, taskId TaskId) : URI in class com.facebook.presto.execution.TestSqlTaskManager.MockLocationFactory |
From |
To |
|
Change Parameter Type nodes : List<Node> to nodes : List<InternalNode> in method private createArbitraryBucketToNode(nodes List<InternalNode>, bucketCount int) : List<InternalNode> in class com.facebook.presto.sql.planner.NodePartitioningManager |
From |
To |
|
Change Parameter Type activeNodes : Set<Node> to activeNodes : Set<InternalNode> in method private announceNodes(activeNodes Set<InternalNode>, inactiveNodes Set<InternalNode>) : void in class com.facebook.presto.metadata.TestDiscoveryNodeManager.PrestoNodeServiceSelector |
From |
To |
|
Change Parameter Type partitionToNode : List<Node> to partitionToNode : List<InternalNode> in method public FixedCountScheduler(stage SqlStageExecution, partitionToNode List<InternalNode>) in class com.facebook.presto.execution.scheduler.FixedCountScheduler |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public addTask(node InternalNode, task RemoteTask) : void in class com.facebook.presto.execution.NodeTaskMap |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method private scheduleTask(node InternalNode, taskId TaskId, sourceSplits Multimap<PlanNodeId,Split>, totalPartitions OptionalInt) : RemoteTask in class com.facebook.presto.execution.SqlStageExecution |
From |
To |
|
Change Parameter Type allNodes : List<Node> to allNodes : List<InternalNode> in method public BucketedSplitPlacementPolicy(nodeSelector NodeSelector, allNodes List<InternalNode>, bucketNodeMap BucketNodeMap, remoteTasks Supplier<? extends List<RemoteTask>>) in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler.BucketedSplitPlacementPolicy |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public getTotalSplitCount(node InternalNode) : int in class com.facebook.presto.execution.scheduler.NodeAssignmentStats |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method private isCoordinator(node InternalNode) : boolean in class com.facebook.presto.connector.system.NodeSystemTable |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public createTaskLocation(node InternalNode, taskId TaskId) : URI in class com.facebook.presto.server.remotetask.HttpLocationFactory |
From |
To |
|
Change Parameter Type nodes : Node... to nodes : InternalNode... in method public addNode(connectorId ConnectorId, nodes InternalNode...) : void in class com.facebook.presto.metadata.InMemoryNodeManager |
From |
To |
|
Change Parameter Type activeNodes : Set<Node> to activeNodes : Set<InternalNode> in method public AllNodes(activeNodes Set<InternalNode>, inactiveNodes Set<InternalNode>, shuttingDownNodes Set<InternalNode>, activeCoordinators Set<InternalNode>) in class com.facebook.presto.metadata.AllNodes |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public addAssignedSplit(node InternalNode) : void in class com.facebook.presto.execution.scheduler.NodeAssignmentStats |
From |
To |
|
Change Parameter Type excludedNodes : Set<Node> to excludedNodes : Set<InternalNode> in method public randomizedNodes(nodeMap NodeMap, includeCoordinator boolean, excludedNodes Set<InternalNode>) : ResettableRandomizedIterator<InternalNode> in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public createTaskLocation(node InternalNode, taskId TaskId) : URI in class com.facebook.presto.execution.LocationFactory |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public createMemoryInfoLocation(node InternalNode) : URI in class com.facebook.presto.execution.TestSqlTaskManager.MockLocationFactory |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public scheduleTask(node InternalNode, partition int, totalPartitions OptionalInt) : Optional<RemoteTask> in class com.facebook.presto.execution.SqlStageExecution |
From |
To |
|
Change Parameter Type excludedNodes : Set<Node> to excludedNodes : Set<InternalNode> in method public selectRandomNodes(limit int, excludedNodes Set<InternalNode>) : List<InternalNode> in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public getPartitionedSplitsOnNode(node InternalNode) : int in class com.facebook.presto.execution.NodeTaskMap |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public abstract assignBucketToNode(bucketedId int, node InternalNode) : void in class com.facebook.presto.execution.scheduler.BucketNodeMap |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public getQueuedSplitCountForStage(node InternalNode) : int in class com.facebook.presto.execution.scheduler.NodeAssignmentStats |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public scheduleTask(node InternalNode, partition int, totalPartitions OptionalInt) : Optional<RemoteTask> in class com.facebook.presto.execution.scheduler.FixedCountScheduler.TaskScheduler |
From |
To |
|
Change Parameter Type partitionToNode : List<Node> to partitionToNode : List<InternalNode> in method public NodePartitionMap(partitionToNode List<InternalNode>, bucketToPartition int[], splitToBucket ToIntFunction<Split>) in class com.facebook.presto.sql.planner.NodePartitionMap |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public createRemoteTask(session Session, taskId TaskId, node InternalNode, fragment PlanFragment, initialSplits Multimap<PlanNodeId,Split>, totalPartitions OptionalInt, outputBuffers OutputBuffers, partitionedSplitCountTracker PartitionedSplitCountTracker, summarizeTaskInfo boolean) : MockRemoteTask in class com.facebook.presto.execution.MockRemoteTaskFactory |
From |
To |
|
Change Parameter Type nodes : Set<Node> to nodes : Set<InternalNode> in method private addRows(table Builder, nodes Set<InternalNode>, state NodeState) : void in class com.facebook.presto.connector.system.NodeSystemTable |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public createRemoteTask(session Session, taskId TaskId, node InternalNode, fragment PlanFragment, initialSplits Multimap<PlanNodeId,Split>, totalPartitions OptionalInt, outputBuffers OutputBuffers, partitionedSplitCountTracker PartitionedSplitCountTracker, summarizeTaskInfo boolean) : RemoteTask in class com.facebook.presto.execution.MemoryTrackingRemoteTaskFactory |
From |
To |
|
Change Parameter Type blockedNodes : Set<Node> to blockedNodes : Set<InternalNode> in method public toWhenHasSplitQueueSpaceFuture(blockedNodes Set<InternalNode>, existingTasks List<RemoteTask>, spaceThreshold int) : ListenableFuture<?> in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Parameter Type candidates : Iterator<Node> to candidates : Iterator<InternalNode> in method private bestNodeSplitCount(candidates Iterator<InternalNode>, minCandidatesWhenFull int, maxPendingSplitsPerTask int, assignmentStats NodeAssignmentStats) : InternalNode in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Parameter Type nodes : List<Node> to nodes : List<InternalNode> in method public FixedSourcePartitionedScheduler(stage SqlStageExecution, splitSources Map<PlanNodeId,SplitSource>, stageExecutionDescriptor StageExecutionDescriptor, schedulingOrder List<PlanNodeId>, nodes List<InternalNode>, bucketNodeMap BucketNodeMap, splitBatchSize int, concurrentLifespansPerTask OptionalInt, nodeSelector NodeSelector, partitionHandles List<ConnectorPartitionHandle>) in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public createRemoteTask(session Session, taskId TaskId, node InternalNode, fragment PlanFragment, initialSplits Multimap<PlanNodeId,Split>, totalPartitions OptionalInt, outputBuffers OutputBuffers, partitionedSplitCountTracker PartitionedSplitCountTracker, summarizeTaskInfo boolean) : RemoteTask in class com.facebook.presto.execution.RemoteTaskFactory |
From |
To |
|
Change Parameter Type splitAssignment : Multimap<Node,Split> to splitAssignment : Multimap<InternalNode,Split> in method private assignSplits(splitAssignment Multimap<InternalNode,Split>, noMoreSplitsNotification Multimap<InternalNode,Lifespan>) : Set<RemoteTask> in class com.facebook.presto.execution.scheduler.SourcePartitionedScheduler |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public createPartitionedSplitCountTracker(node InternalNode, taskId TaskId) : PartitionedSplitCountTracker in class com.facebook.presto.execution.NodeTaskMap |
From |
To |
|
Change Parameter Type candidates : ResettableRandomizedIterator<Node> to candidates : ResettableRandomizedIterator<InternalNode> in method public selectNodes(limit int, candidates ResettableRandomizedIterator<InternalNode>) : List<InternalNode> in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method private addNodeTask(node InternalNode) : NodeTasks in class com.facebook.presto.execution.NodeTaskMap |
From |
To |
|
Change Parameter Type node : Node to node : InternalNode in method public createMemoryInfoLocation(node InternalNode) : URI in class com.facebook.presto.server.remotetask.HttpLocationFactory |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public allNodes() : List<InternalNode> in class com.facebook.presto.execution.scheduler.SimpleNodeSelector |
From |
To |
|
Change Return Type Optional<Node> to Optional<InternalNode> in method public abstract getAssignedNode(bucketedId int) : Optional<InternalNode> in class com.facebook.presto.execution.scheduler.BucketNodeMap |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method private generateRandomNodes(count int) : List<InternalNode> in class com.facebook.presto.execution.scheduler.TestFixedCountScheduler |
From |
To |
|
Change Return Type Node to InternalNode in method public selectCurrentNode() : InternalNode in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getActiveCoordinators() : Set<InternalNode> in class com.facebook.presto.metadata.AllNodes |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getActiveConnectorNodes(connectorId ConnectorId) : Set<InternalNode> in class com.facebook.presto.metadata.InternalNodeManager |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public allNodes() : List<InternalNode> in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler.BucketedSplitPlacementPolicy |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getNodes(state NodeState) : Set<InternalNode> in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Return Type SetMultimap<NetworkLocation,Node> to SetMultimap<NetworkLocation,InternalNode> in method public getWorkersByNetworkPath() : SetMultimap<NetworkLocation,InternalNode> in class com.facebook.presto.execution.scheduler.NodeMap |
From |
To |
|
Change Return Type Optional<Node> to Optional<InternalNode> in method public getAssignedNode(bucketedId int) : Optional<InternalNode> in class com.facebook.presto.execution.scheduler.FixedBucketNodeMap |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public selectRandomNodes(limit int, excludedNodes Set<InternalNode>) : List<InternalNode> in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public getPartitionToNode() : List<InternalNode> in class com.facebook.presto.sql.planner.NodePartitionMap |
From |
To |
|
Change Return Type Node to InternalNode in method public getCurrentNode() : InternalNode in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method private createArbitraryBucketToNode(nodes List<InternalNode>, bucketCount int) : List<InternalNode> in class com.facebook.presto.sql.planner.NodePartitioningManager |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getCoordinators() : Set<InternalNode> in class com.facebook.presto.metadata.InternalNodeManager |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getActiveNodesWithConnector(connectorId ConnectorId) : Set<InternalNode> in class com.facebook.presto.server.testing.TestingPrestoServer |
From |
To |
|
Change Return Type Map<Node,MockRemoteTaskFactory.MockRemoteTask> to Map<InternalNode,MockRemoteTaskFactory.MockRemoteTask> in method public getTaskMap() : Map<InternalNode,MockRemoteTaskFactory.MockRemoteTask> in class com.facebook.presto.execution.BenchmarkNodeScheduler.BenchmarkData |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getNodes(state NodeState) : Set<InternalNode> in class com.facebook.presto.metadata.InMemoryNodeManager |
From |
To |
|
Change Return Type Optional<Node> to Optional<InternalNode> in method public getAssignedNode(bucketedId int) : Optional<InternalNode> in class com.facebook.presto.execution.scheduler.group.DynamicBucketNodeMap |
From |
To |
|
Change Return Type SetMultimap<InetAddress,Node> to SetMultimap<InetAddress,InternalNode> in method public getNodesByHost() : SetMultimap<InetAddress,InternalNode> in class com.facebook.presto.execution.scheduler.NodeMap |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getActiveConnectorNodes(connectorId ConnectorId) : Set<InternalNode> in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public allNodes() : List<InternalNode> in class com.facebook.presto.execution.scheduler.SplitPlacementPolicy |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public selectRandomNodes(limit int, excludedNodes Set<InternalNode>) : List<InternalNode> in class com.facebook.presto.execution.scheduler.SimpleNodeSelector |
From |
To |
|
Change Return Type Optional<Node> to Optional<InternalNode> in method public getAssignedNode(split Split) : Optional<InternalNode> in class com.facebook.presto.execution.scheduler.BucketNodeMap |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public allNodes() : List<InternalNode> in class com.facebook.presto.execution.scheduler.DynamicSplitPlacementPolicy |
From |
To |
|
Change Return Type Node to InternalNode in method public getCurrentNode() : InternalNode in class com.facebook.presto.metadata.InternalNodeManager |
From |
To |
|
Change Return Type Node to InternalNode in method public selectCurrentNode() : InternalNode in class com.facebook.presto.execution.scheduler.NodeSelector |
From |
To |
|
Change Return Type Node to InternalNode in method private bestNodeSplitCount(candidates Iterator<InternalNode>, minCandidatesWhenFull int, maxPendingSplitsPerTask int, assignmentStats NodeAssignmentStats) : InternalNode in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Return Type Node to InternalNode in method public getNode(split Split) : InternalNode in class com.facebook.presto.sql.planner.NodePartitionMap |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public selectNodes(limit int, candidates ResettableRandomizedIterator<InternalNode>) : List<InternalNode> in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getShuttingDownNodes() : Set<InternalNode> in class com.facebook.presto.metadata.AllNodes |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public allNodes() : List<InternalNode> in class com.facebook.presto.execution.scheduler.NodeSelector |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getInactiveNodes() : Set<InternalNode> in class com.facebook.presto.metadata.AllNodes |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public selectRandomNodes(limit int) : List<InternalNode> in class com.facebook.presto.execution.scheduler.NodeSelector |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getActiveConnectorNodes(connectorId ConnectorId) : Set<InternalNode> in class com.facebook.presto.metadata.InMemoryNodeManager |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public selectExactNodes(nodeMap NodeMap, hosts List<HostAddress>, includeCoordinator boolean) : List<InternalNode> in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public allNodes() : List<InternalNode> in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Return Type Node to InternalNode in method public getNode() : InternalNode in class com.facebook.presto.memory.RemoteNodeMemory |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getCoordinators() : Set<InternalNode> in class com.facebook.presto.metadata.InMemoryNodeManager |
From |
To |
|
Change Return Type Node to InternalNode in method public getNodeForBucket(bucketId int) : InternalNode in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler.BucketedSplitPlacementPolicy |
From |
To |
|
Change Return Type Multimap<Node,Split> to Multimap<InternalNode,Split> in method public getAssignments() : Multimap<InternalNode,Split> in class com.facebook.presto.execution.scheduler.SplitPlacementResult |
From |
To |
|
Change Return Type List<Node> to List<InternalNode> in method public selectRandomNodes(limit int, excludedNodes Set<InternalNode>) : List<InternalNode> in class com.facebook.presto.execution.scheduler.NodeSelector |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getCoordinators() : Set<InternalNode> in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getActiveNodes() : Set<InternalNode> in class com.facebook.presto.metadata.AllNodes |
From |
To |
|
Change Return Type Node to InternalNode in method public selectCurrentNode() : InternalNode in class com.facebook.presto.execution.scheduler.SimpleNodeSelector |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getScheduledNodes() : Set<InternalNode> in class com.facebook.presto.execution.SqlStageExecution |
From |
To |
|
Change Return Type Set<Node> to Set<InternalNode> in method public getNodes(state NodeState) : Set<InternalNode> in class com.facebook.presto.metadata.InternalNodeManager |
From |
To |
|
Change Return Type SetMultimap<HostAddress,Node> to SetMultimap<HostAddress,InternalNode> in method public getNodesByHostAndPort() : SetMultimap<HostAddress,InternalNode> in class com.facebook.presto.execution.scheduler.NodeMap |
From |
To |
|
Change Return Type Node to InternalNode in method public getCurrentNode() : InternalNode in class com.facebook.presto.metadata.InMemoryNodeManager |
From |
To |
|
Change Return Type ResettableRandomizedIterator<Node> to ResettableRandomizedIterator<InternalNode> in method public randomizedNodes(nodeMap NodeMap, includeCoordinator boolean, excludedNodes Set<InternalNode>) : ResettableRandomizedIterator<InternalNode> in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Variable Type assignments : Multimap<Node,Split> to assignments : Multimap<InternalNode,Split> in method public testScheduleRemote() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type nodes : ImmutableSet.Builder<Node> to nodes : ImmutableSet.Builder<InternalNode> in method public getSplits(transactionHandle ConnectorTransactionHandle, session ConnectorSession, layout ConnectorTableLayoutHandle, splitSchedulingStrategy SplitSchedulingStrategy) : ConnectorSplitSource in class com.facebook.presto.connector.system.SystemSplitManager |
From |
To |
|
Change Variable Type assignment : Map.Entry<Node,Split> to assignment : Map.Entry<InternalNode,Split> in method public testScheduleLocal() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method private pollWorkers() : void in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Variable Type assignments : Multimap<Node,Split> to assignments : Multimap<InternalNode,Split> in method public benchmark(data BenchmarkData) : Object in class com.facebook.presto.execution.BenchmarkNodeScheduler |
From |
To |
|
Change Variable Type nodes : List<Node> to nodes : List<InternalNode> in method private scheduleTasks(count int) : List<RemoteTask> in class com.facebook.presto.execution.scheduler.ScaledWriterScheduler |
From |
To |
|
Change Variable Type partitionToNode : List<Node> to partitionToNode : List<InternalNode> in method private createStreamingLinkedStages(parent ExchangeLocationsConsumer, locationFactory LocationFactory, plan StreamingSubPlan, nodeScheduler NodeScheduler, remoteTaskFactory RemoteTaskFactory, splitSourceFactory SplitSourceFactory, session Session, splitBatchSize int, partitioningCache Function<PartitioningHandle,NodePartitionMap>, nodePartitioningManager NodePartitioningManager, queryExecutor ExecutorService, schedulerExecutor ScheduledExecutorService, failureDetector FailureDetector, nodeTaskMap NodeTaskMap, stageSchedulers ImmutableMap.Builder<StageId,StageScheduler>, stageLinkages ImmutableMap.Builder<StageId,StageLinkage>) : List<SqlStageExecution> in class com.facebook.presto.execution.scheduler.SqlQueryScheduler |
From |
To |
|
Change Variable Type blockedExactNodes : Set<Node> to blockedExactNodes : Set<InternalNode> in method public computeAssignments(splits Set<Split>, existingTasks List<RemoteTask>) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.SimpleNodeSelector |
From |
To |
|
Change Variable Type nodes : ImmutableList<Node> to nodes : ImmutableList<InternalNode> in method public randomizedNodes(nodeMap NodeMap, includeCoordinator boolean, excludedNodes Set<InternalNode>) : ResettableRandomizedIterator<InternalNode> in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Variable Type newNode : Node to newNode : InternalNode in method public testMaxSplitsPerNodePerTask() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public getNodePartitioningMap(session Session, partitioningHandle PartitioningHandle) : NodePartitionMap in class com.facebook.presto.sql.planner.NodePartitioningManager |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public testBasicAssignment() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type nodeToDriverGroupMap : Map<Node,IntList> to nodeToDriverGroupMap : Map<InternalNode,IntList> in method public FixedLifespanScheduler(bucketNodeMap BucketNodeMap, partitionHandles List<ConnectorPartitionHandle>, concurrentLifespansPerTask OptionalInt) in class com.facebook.presto.execution.scheduler.group.FixedLifespanScheduler |
From |
To |
|
Change Variable Type byConnectorIdBuilder : ImmutableSetMultimap.Builder<ConnectorId,Node> to byConnectorIdBuilder : ImmutableSetMultimap.Builder<ConnectorId,InternalNode> in method private refreshNodesInternal() : void in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Variable Type nodeReservations : Map<Node,NodeReservation> to nodeReservations : Map<InternalNode,NodeReservation> in method package toNodeMemoryInfoList(maxReservedPoolBytes long, maxGeneralPoolBytes long, reservedQuery String, queries Map<String,Map<String,Long>>) : List<MemoryInfo> in class com.facebook.presto.memory.LowMemoryKillerTestingUtils |
From |
To |
|
Change Variable Type chosen : Set<Node> to chosen : Set<InternalNode> in method public selectExactNodes(nodeMap NodeMap, hosts List<HostAddress>, includeCoordinator boolean) : List<InternalNode> in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Variable Type inactiveNodes : Set<Node> to inactiveNodes : Set<InternalNode> in method public testGetAllNodes() : void in class com.facebook.presto.metadata.TestDiscoveryNodeManager |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public testMaxSplitsPerNodePerTask() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type nodeToPartition : BiMap<Node,Integer> to nodeToPartition : BiMap<InternalNode,Integer> in method public getNodePartitioningMap(session Session, partitioningHandle PartitioningHandle) : NodePartitionMap in class com.facebook.presto.sql.planner.NodePartitioningManager |
From |
To |
|
Change Variable Type nodeBuilder : ImmutableList.Builder<Node> to nodeBuilder : ImmutableList.Builder<InternalNode> in method public setup() : void in class com.facebook.presto.execution.BenchmarkNodeScheduler.BenchmarkData |
From |
To |
|
Change Variable Type randomCandidates : ResettableRandomizedIterator<Node> to randomCandidates : ResettableRandomizedIterator<InternalNode> in method public computeAssignments(splits Set<Split>, existingTasks List<RemoteTask>) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.SimpleNodeSelector |
From |
To |
|
Change Variable Type missingNodes : SetView<Node> to missingNodes : SetView<InternalNode> in method private refreshNodesInternal() : void in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Variable Type activeNodes : Set<Node> to activeNodes : Set<InternalNode> in method public TaskCountEstimator(nodeSchedulerConfig NodeSchedulerConfig, nodeManager InternalNodeManager) in class com.facebook.presto.cost.TaskCountEstimator |
From |
To |
|
Change Variable Type nodes : ImmutableSet<Node> to nodes : ImmutableSet<InternalNode> in method private assignSplits(splitAssignment Multimap<InternalNode,Split>, noMoreSplitsNotification Multimap<InternalNode,Lifespan>) : Set<RemoteTask> in class com.facebook.presto.execution.scheduler.SourcePartitionedScheduler |
From |
To |
|
Change Variable Type entry : Map.Entry<Node,IntListIterator> to entry : Map.Entry<InternalNode,IntListIterator> in method public scheduleInitial(scheduler SourceScheduler) : void in class com.facebook.presto.execution.scheduler.group.FixedLifespanScheduler |
From |
To |
|
Change Variable Type nodeBuilder : ImmutableList.Builder<Node> to nodeBuilder : ImmutableList.Builder<InternalNode> in method public testTopologyAwareScheduling() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type nodes : Set<Node> to nodes : Set<InternalNode> in method public computeAssignments(splits Set<Split>, existingTasks List<RemoteTask>) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Variable Type partitionToNode : List<Node> to partitionToNode : List<InternalNode> in method public getNodePartitioningMap(session Session, partitioningHandle PartitioningHandle) : NodePartitionMap in class com.facebook.presto.sql.planner.NodePartitioningManager |
From |
To |
|
Change Variable Type assignments : Multimap<Node,Split> to assignments : Multimap<InternalNode,Split> in method public testMaxSplitsPerNodePerTask() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public schedule() : ScheduleResult in class com.facebook.presto.execution.scheduler.SourcePartitionedScheduler |
From |
To |
|
Change Variable Type assignments : Multimap<Node,Split> to assignments : Multimap<InternalNode,Split> in method public selectDistributionNodes(nodeMap NodeMap, nodeTaskMap NodeTaskMap, maxSplitsPerNode int, maxPendingSplitsPerTask int, splits Set<Split>, existingTasks List<RemoteTask>, bucketNodeMap BucketNodeMap) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Variable Type nodeSet : Set<Node> to nodeSet : Set<InternalNode> in method public getSplits(transactionHandle ConnectorTransactionHandle, session ConnectorSession, layout ConnectorTableLayoutHandle, splitSchedulingStrategy SplitSchedulingStrategy) : ConnectorSplitSource in class com.facebook.presto.connector.system.SystemSplitManager |
From |
To |
|
Change Variable Type bucketToNode : List<Node> to bucketToNode : List<InternalNode> in method public getNodePartitioningMap(session Session, partitioningHandle PartitioningHandle) : NodePartitionMap in class com.facebook.presto.sql.planner.NodePartitioningManager |
From |
To |
|
Change Variable Type aliveNodes : Set<Node> to aliveNodes : Set<InternalNode> in method private pollWorkers() : void in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Variable Type inactiveNodesBuilder : ImmutableSet.Builder<Node> to inactiveNodesBuilder : ImmutableSet.Builder<InternalNode> in method private refreshNodesInternal() : void in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Variable Type activeNodes : Set<Node> to activeNodes : Set<InternalNode> in method public testGetAllNodes() : void in class com.facebook.presto.metadata.TestDiscoveryNodeManager |
From |
To |
|
Change Variable Type splitAssignment : Multimap<Node,Split> to splitAssignment : Multimap<InternalNode,Split> in method public schedule() : ScheduleResult in class com.facebook.presto.execution.scheduler.SourcePartitionedScheduler |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public createNodeSelector(connectorId ConnectorId) : NodeSelector in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Variable Type blockedExactNodes : Set<Node> to blockedExactNodes : Set<InternalNode> in method public computeAssignments(splits Set<Split>, existingTasks List<RemoteTask>) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Variable Type nodeForCompletedDriverGroup : Node to nodeForCompletedDriverGroup : InternalNode in method public schedule(scheduler SourceScheduler) : SettableFuture in class com.facebook.presto.execution.scheduler.group.DynamicLifespanScheduler |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method private assignSplits(splitAssignment Multimap<InternalNode,Split>, noMoreSplitsNotification Multimap<InternalNode,Lifespan>) : Set<RemoteTask> in class com.facebook.presto.execution.scheduler.SourcePartitionedScheduler |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method private proxyJsonResponse(nodeId String, workerPath String) : Response in class com.facebook.presto.server.WorkerResource |
From |
To |
|
Change Variable Type nodes : List<Node> to nodes : List<InternalNode> in method public getNodePartitionMap(session Session, nodeScheduler NodeScheduler) : NodePartitionMap in class com.facebook.presto.sql.planner.SystemPartitioningHandle |
From |
To |
|
Change Variable Type shuttingDownNodesBuilder : ImmutableSet.Builder<Node> to shuttingDownNodesBuilder : ImmutableSet.Builder<InternalNode> in method private refreshNodesInternal() : void in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Variable Type activeNodesWithConnector : Set<Node> to activeNodesWithConnector : Set<InternalNode> in method private refreshNodes(connectorId ConnectorId) : void in class com.facebook.presto.tests.StandaloneQueryRunner |
From |
To |
|
Change Variable Type bestQueueNotFull : Node to bestQueueNotFull : InternalNode in method private bestNodeSplitCount(candidates Iterator<InternalNode>, minCandidatesWhenFull int, maxPendingSplitsPerTask int, assignmentStats NodeAssignmentStats) : InternalNode in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Variable Type actual : Node to actual : InternalNode in method public testGetAllNodes() : void in class com.facebook.presto.metadata.TestDiscoveryNodeManager |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public benchmark(data BenchmarkData) : Object in class com.facebook.presto.execution.BenchmarkNodeScheduler |
From |
To |
|
Change Variable Type assignments : Multimap<Node,Split> to assignments : Multimap<InternalNode,Split> in method public testBasicAssignment() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type aliveNodes : Set<Node> to aliveNodes : Set<InternalNode> in method private updateNodes(assignments MemoryPoolAssignmentsRequest) : void in class com.facebook.presto.memory.ClusterMemoryManager |
From |
To |
|
Change Variable Type missingNode : Node to missingNode : InternalNode in method private refreshNodesInternal() : void in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Variable Type noMoreSplitsNotification : Multimap<Node,Lifespan> to noMoreSplitsNotification : Multimap<InternalNode,Lifespan> in method public schedule() : ScheduleResult in class com.facebook.presto.execution.scheduler.SourcePartitionedScheduler |
From |
To |
|
Change Variable Type chosenNode : Node to chosenNode : InternalNode in method public testTaskCompletion() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type builder : ImmutableSet.Builder<Node> to builder : ImmutableSet.Builder<InternalNode> in method private updateNodes(assignments MemoryPoolAssignmentsRequest) : void in class com.facebook.presto.memory.ClusterMemoryManager |
From |
To |
|
Change Variable Type byHostAndPort : ImmutableSetMultimap.Builder<HostAddress,Node> to byHostAndPort : ImmutableSetMultimap.Builder<HostAddress,InternalNode> in method public createNodeSelector(connectorId ConnectorId) : NodeSelector in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Variable Type scheduledNodes : Set<Node> to scheduledNodes : Set<InternalNode> in method private finalizeTaskCreationIfNecessary() : Set<RemoteTask> in class com.facebook.presto.execution.scheduler.SourcePartitionedScheduler |
From |
To |
|
Change Variable Type taskMap : Map<Node,RemoteTask> to taskMap : Map<InternalNode,RemoteTask> in method public testTopologyAwareScheduling() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type additionalNode : Node to additionalNode : InternalNode in method public testBalancedSplitAssignment() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type nodes : ImmutableList<Node> to nodes : ImmutableList<InternalNode> in method public setUp() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type nodes : Set<Node> to nodes : Set<InternalNode> in method public createNodeSelector(connectorId ConnectorId) : NodeSelector in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Variable Type assignment : Multimap<Node,Split> to assignment : Multimap<InternalNode,Split> in method public computeAssignments(splits Set<Split>, existingTasks List<RemoteTask>) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.SimpleNodeSelector |
From |
To |
|
Change Variable Type selected : List<Node> to selected : List<InternalNode> in method public selectNodes(limit int, candidates ResettableRandomizedIterator<InternalNode>) : List<InternalNode> in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Variable Type driverGroupToNodeMap : Int2ObjectMap<Node> to driverGroupToNodeMap : Int2ObjectMap<InternalNode> in method public FixedLifespanScheduler(bucketNodeMap BucketNodeMap, partitionHandles List<ConnectorPartitionHandle>, concurrentLifespansPerTask OptionalInt) in class com.facebook.presto.execution.scheduler.group.FixedLifespanScheduler |
From |
To |
|
Change Variable Type nodes : Set<Node> to nodes : Set<InternalNode> in method private proxyJsonResponse(nodeId String, workerPath String) : Response in class com.facebook.presto.server.WorkerResource |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public selectDistributionNodes(nodeMap NodeMap, nodeTaskMap NodeTaskMap, maxSplitsPerNode int, maxPendingSplitsPerTask int, splits Set<Split>, existingTasks List<RemoteTask>, bucketNodeMap BucketNodeMap) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Variable Type expected : Node to expected : InternalNode in method public testGetAllNodes() : void in class com.facebook.presto.metadata.TestDiscoveryNodeManager |
From |
To |
|
Change Variable Type candidateNodes : List<Node> to candidateNodes : List<InternalNode> in method public computeAssignments(splits Set<Split>, existingTasks List<RemoteTask>) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.SimpleNodeSelector |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public getSplits(transactionHandle ConnectorTransactionHandle, session ConnectorSession, layout ConnectorTableLayoutHandle, splitSchedulingStrategy SplitSchedulingStrategy) : ConnectorSplitSource in class com.facebook.presto.connector.system.SystemSplitManager |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public testTopologyAwareScheduling() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public FixedLifespanScheduler(bucketNodeMap BucketNodeMap, partitionHandles List<ConnectorPartitionHandle>, concurrentLifespansPerTask OptionalInt) in class com.facebook.presto.execution.scheduler.group.FixedLifespanScheduler |
From |
To |
|
Change Variable Type nodeBuilder : ImmutableList.Builder<Node> to nodeBuilder : ImmutableList.Builder<InternalNode> in method public setUp() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method private bestNodeSplitCount(candidates Iterator<InternalNode>, minCandidatesWhenFull int, maxPendingSplitsPerTask int, assignmentStats NodeAssignmentStats) : InternalNode in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Variable Type candidateNodes : List<Node> to candidateNodes : List<InternalNode> in method public computeAssignments(splits Set<Split>, existingTasks List<RemoteTask>) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Variable Type stageNodeList : List<Node> to stageNodeList : List<InternalNode> in method private createStreamingLinkedStages(parent ExchangeLocationsConsumer, locationFactory LocationFactory, plan StreamingSubPlan, nodeScheduler NodeScheduler, remoteTaskFactory RemoteTaskFactory, splitSourceFactory SplitSourceFactory, session Session, splitBatchSize int, partitioningCache Function<PartitioningHandle,NodePartitionMap>, nodePartitioningManager NodePartitioningManager, queryExecutor ExecutorService, schedulerExecutor ScheduledExecutorService, failureDetector FailureDetector, nodeTaskMap NodeTaskMap, stageSchedulers ImmutableMap.Builder<StageId,StageScheduler>, stageLinkages ImmutableMap.Builder<StageId,StageLinkage>) : List<SqlStageExecution> in class com.facebook.presto.execution.scheduler.SqlQueryScheduler |
From |
To |
|
Change Variable Type nodes : ImmutableList<Node> to nodes : ImmutableList<InternalNode> in method public testTopologyAwareScheduling() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public setup() : void in class com.facebook.presto.execution.BenchmarkNodeScheduler.BenchmarkData |
From |
To |
|
Change Variable Type bucketToNode : ImmutableList.Builder<Node> to bucketToNode : ImmutableList.Builder<InternalNode> in method public asBucketNodeMap() : BucketNodeMap in class com.facebook.presto.sql.planner.NodePartitionMap |
From |
To |
|
Change Variable Type entry : Map.Entry<Node,NodeReservation> to entry : Map.Entry<InternalNode,NodeReservation> in method package toNodeMemoryInfoList(maxReservedPoolBytes long, maxGeneralPoolBytes long, reservedQuery String, queries Map<String,Map<String,Long>>) : List<MemoryInfo> in class com.facebook.presto.memory.LowMemoryKillerTestingUtils |
From |
To |
|
Change Variable Type newNode : Node to newNode : InternalNode in method public testMaxSplitsPerNode() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type chosenNode : Node to chosenNode : InternalNode in method public computeAssignments(splits Set<Split>, existingTasks List<RemoteTask>) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Variable Type activeNodesWithConnector : Set<Node> to activeNodesWithConnector : Set<InternalNode> in method private isConnectionVisibleToAllNodes(connectorId ConnectorId) : boolean in class com.facebook.presto.tests.DistributedQueryRunner |
From |
To |
|
Change Variable Type assignments : Multimap<Node,Split> to assignments : Multimap<InternalNode,Split> in method public testTopologyAwareScheduling() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type byHost : ImmutableSetMultimap.Builder<InetAddress,Node> to byHost : ImmutableSetMultimap.Builder<InetAddress,InternalNode> in method public createNodeSelector(connectorId ConnectorId) : NodeSelector in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Variable Type assignments : Multimap<Node,Split> to assignments : Multimap<InternalNode,Split> in method public testMaxSplitsPerNode() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method private scheduleTasks(count int) : List<RemoteTask> in class com.facebook.presto.execution.scheduler.ScaledWriterScheduler |
From |
To |
|
Change Variable Type activeNodesBuilder : ImmutableSet.Builder<Node> to activeNodesBuilder : ImmutableSet.Builder<InternalNode> in method private refreshNodesInternal() : void in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method private updateNodes(assignments MemoryPoolAssignmentsRequest) : void in class com.facebook.presto.memory.ClusterMemoryManager |
From |
To |
|
Change Variable Type blockedNodes : Set<Node> to blockedNodes : Set<InternalNode> in method public selectDistributionNodes(nodeMap NodeMap, nodeTaskMap NodeTaskMap, maxSplitsPerNode int, maxPendingSplitsPerTask int, splits Set<Split>, existingTasks List<RemoteTask>, bucketNodeMap BucketNodeMap) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Variable Type chosenNode : Node to chosenNode : InternalNode in method public testSplitCount() : void in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Variable Type assignment : Multimap<Node,Split> to assignment : Multimap<InternalNode,Split> in method public computeAssignments(splits Set<Split>, existingTasks List<RemoteTask>) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.TopologyAwareNodeSelector |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method private announceNodes(activeNodes Set<InternalNode>, inactiveNodes Set<InternalNode>) : void in class com.facebook.presto.metadata.TestDiscoveryNodeManager.PrestoNodeServiceSelector |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method private addRows(table Builder, nodes Set<InternalNode>, state NodeState) : void in class com.facebook.presto.connector.system.NodeSystemTable |
From |
To |
|
Change Variable Type nodes : List<Node> to nodes : List<InternalNode> in method public setup() : void in class com.facebook.presto.execution.BenchmarkNodeScheduler.BenchmarkData |
From |
To |
|
Change Variable Type workersByNetworkPath : ImmutableSetMultimap.Builder<NetworkLocation,Node> to workersByNetworkPath : ImmutableSetMultimap.Builder<NetworkLocation,InternalNode> in method public createNodeSelector(connectorId ConnectorId) : NodeSelector in class com.facebook.presto.execution.scheduler.NodeScheduler |
From |
To |
|
Change Variable Type chosenNode : Node to chosenNode : InternalNode in method public computeAssignments(splits Set<Split>, existingTasks List<RemoteTask>) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.SimpleNodeSelector |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public computeAssignments(splits Set<Split>, existingTasks List<RemoteTask>) : SplitPlacementResult in class com.facebook.presto.execution.scheduler.SimpleNodeSelector |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method public NodeAssignmentStats(nodeTaskMap NodeTaskMap, nodeMap NodeMap, existingTasks List<RemoteTask>) in class com.facebook.presto.execution.scheduler.NodeAssignmentStats |
From |
To |
|
Change Variable Type node : Node to node : InternalNode in method private testFinalStageInfoInternal() : void in class com.facebook.presto.execution.TestSqlStageExecution |
From |
To |
|
Change Variable Type coordinatorsBuilder : ImmutableSet.Builder<Node> to coordinatorsBuilder : ImmutableSet.Builder<InternalNode> in method private refreshNodesInternal() : void in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Attribute Type nodeTasksMap : ConcurrentHashMap<Node,NodeTasks> to nodeTasksMap : ConcurrentHashMap<InternalNode,NodeTasks> in class com.facebook.presto.execution.NodeTaskMap |
From |
To |
|
Change Attribute Type driverGroupToNodeMap : Int2ObjectMap<Node> to driverGroupToNodeMap : Int2ObjectMap<InternalNode> in class com.facebook.presto.execution.scheduler.group.FixedLifespanScheduler |
From |
To |
|
Change Attribute Type remoteNodes : SetMultimap<ConnectorId,Node> to remoteNodes : SetMultimap<ConnectorId,InternalNode> in class com.facebook.presto.metadata.InMemoryNodeManager |
From |
To |
|
Change Attribute Type allNodes : List<Node> to allNodes : List<InternalNode> in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler.BucketedSplitPlacementPolicy |
From |
To |
|
Change Attribute Type scheduledNodes : Set<Node> to scheduledNodes : Set<InternalNode> in class com.facebook.presto.execution.scheduler.ScaledWriterScheduler |
From |
To |
|
Change Attribute Type partitionToNode : List<Node> to partitionToNode : List<InternalNode> in class com.facebook.presto.execution.scheduler.FixedCountScheduler |
From |
To |
|
Change Attribute Type nodesByHost : SetMultimap<InetAddress,Node> to nodesByHost : SetMultimap<InetAddress,InternalNode> in class com.facebook.presto.execution.scheduler.NodeMap |
From |
To |
|
Change Attribute Type assignmentCount : Map<Node,Integer> to assignmentCount : Map<InternalNode,Integer> in class com.facebook.presto.execution.scheduler.NodeAssignmentStats |
From |
To |
|
Change Attribute Type taskMap : Map<Node,MockRemoteTaskFactory.MockRemoteTask> to taskMap : Map<InternalNode,MockRemoteTaskFactory.MockRemoteTask> in class com.facebook.presto.execution.BenchmarkNodeScheduler.BenchmarkData |
From |
To |
|
Change Attribute Type node : Node to node : InternalNode in class com.facebook.presto.memory.RemoteNodeMemory |
From |
To |
|
Change Attribute Type partitionToNode : List<Node> to partitionToNode : List<InternalNode> in class com.facebook.presto.sql.planner.NodePartitionMap |
From |
To |
|
Change Attribute Type allNodes : List<Node> to allNodes : List<InternalNode> in class com.facebook.presto.execution.scheduler.group.DynamicLifespanScheduler |
From |
To |
|
Change Attribute Type activeNodesByConnectorId : SetMultimap<ConnectorId,Node> to activeNodesByConnectorId : SetMultimap<ConnectorId,InternalNode> in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Attribute Type activeNodes : Set<Node> to activeNodes : Set<InternalNode> in class com.facebook.presto.metadata.AllNodes |
From |
To |
|
Change Attribute Type bucketToNode : List<Node> to bucketToNode : List<InternalNode> in class com.facebook.presto.execution.scheduler.FixedBucketNodeMap |
From |
To |
|
Change Attribute Type inactiveNodes : Set<Node> to inactiveNodes : Set<InternalNode> in class com.facebook.presto.metadata.AllNodes |
From |
To |
|
Change Attribute Type coordinators : Set<Node> to coordinators : Set<InternalNode> in class com.facebook.presto.metadata.DiscoveryNodeManager |
From |
To |
|
Change Attribute Type taskMap : Map<Node,RemoteTask> to taskMap : Map<InternalNode,RemoteTask> in class com.facebook.presto.execution.TestNodeScheduler |
From |
To |
|
Change Attribute Type nodesByHostAndPort : SetMultimap<HostAddress,Node> to nodesByHostAndPort : SetMultimap<HostAddress,InternalNode> in class com.facebook.presto.execution.scheduler.NodeMap |
From |
To |
|
Change Attribute Type localNode : Node to localNode : InternalNode in class com.facebook.presto.metadata.InMemoryNodeManager |
From |
To |
|
Change Attribute Type bucketToNode : Int2ObjectMap<Node> to bucketToNode : Int2ObjectMap<InternalNode> in class com.facebook.presto.execution.scheduler.group.DynamicBucketNodeMap |
From |
To |
|
Change Attribute Type nodeToDriverGroupsMap : Map<Node,IntListIterator> to nodeToDriverGroupsMap : Map<InternalNode,IntListIterator> in class com.facebook.presto.execution.scheduler.group.FixedLifespanScheduler |
From |
To |
|
Change Attribute Type nodes : List<Node> to nodes : List<InternalNode> in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler |
From |
To |
|
Change Attribute Type tasks : Map<Node,Set<RemoteTask>> to tasks : Map<InternalNode,Set<RemoteTask>> in class com.facebook.presto.execution.SqlStageExecution |
From |
To |
|
Change Attribute Type workersByNetworkPath : SetMultimap<NetworkLocation,Node> to workersByNetworkPath : SetMultimap<NetworkLocation,InternalNode> in class com.facebook.presto.execution.scheduler.NodeMap |
From |
To |
|
Change Attribute Type activeNodes : Set<Node> to activeNodes : Set<InternalNode> in class com.facebook.presto.metadata.TestDiscoveryNodeManager |
From |
To |
|
Change Attribute Type shuttingDownNodes : Set<Node> to shuttingDownNodes : Set<InternalNode> in class com.facebook.presto.metadata.AllNodes |
From |
To |
|
Change Attribute Type activeCoordinators : Set<Node> to activeCoordinators : Set<InternalNode> in class com.facebook.presto.metadata.AllNodes |
From |
To |
|
Change Attribute Type inactiveNodes : Set<Node> to inactiveNodes : Set<InternalNode> in class com.facebook.presto.metadata.TestDiscoveryNodeManager |
From |
To |
|
Change Attribute Type splitCountByNode : Map<Node,Integer> to splitCountByNode : Map<InternalNode,Integer> in class com.facebook.presto.execution.scheduler.NodeAssignmentStats |
From |
To |
|
Change Attribute Type assignments : Multimap<Node,Split> to assignments : Multimap<InternalNode,Split> in class com.facebook.presto.execution.scheduler.SplitPlacementResult |
From |
To |