Many resources are needed to download a project. Please understand that we have to compensate our server costs. Thank you in advance. Project price only 1 $
You can buy this project and download/modify it how often you want.
/*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
package io.trino.execution;
import com.google.common.collect.Multimap;
import io.airlift.units.DataSize;
import io.opentelemetry.api.trace.Span;
import io.trino.Session;
import io.trino.execution.NodeTaskMap.PartitionedSplitCountTracker;
import io.trino.execution.StateMachine.StateChangeListener;
import io.trino.execution.buffer.OutputBuffers;
import io.trino.metadata.InternalNode;
import io.trino.metadata.Split;
import io.trino.sql.planner.PlanFragment;
import io.trino.sql.planner.plan.DynamicFilterId;
import io.trino.sql.planner.plan.PlanNodeId;
import java.util.Optional;
import java.util.Set;
import static java.util.Objects.requireNonNull;
public class MemoryTrackingRemoteTaskFactory
implements RemoteTaskFactory
{
private final RemoteTaskFactory remoteTaskFactory;
private final QueryStateMachine stateMachine;
public MemoryTrackingRemoteTaskFactory(RemoteTaskFactory remoteTaskFactory, QueryStateMachine stateMachine)
{
this.remoteTaskFactory = requireNonNull(remoteTaskFactory, "remoteTaskFactory is null");
this.stateMachine = requireNonNull(stateMachine, "stateMachine is null");
}
@Override
public RemoteTask createRemoteTask(
Session session,
Span stageSpan,
TaskId taskId,
InternalNode node,
boolean speculative,
PlanFragment fragment,
Multimap initialSplits,
OutputBuffers outputBuffers,
PartitionedSplitCountTracker partitionedSplitCountTracker,
Set outboundDynamicFilterIds,
Optional estimatedMemory,
boolean summarizeTaskInfo)
{
RemoteTask task = remoteTaskFactory.createRemoteTask(
session,
stageSpan,
taskId,
node,
speculative,
fragment,
initialSplits,
outputBuffers,
partitionedSplitCountTracker,
outboundDynamicFilterIds,
estimatedMemory,
summarizeTaskInfo);
task.addStateChangeListener(new UpdatePeakMemory(stateMachine));
return task;
}
private static final class UpdatePeakMemory
implements StateChangeListener
{
private final QueryStateMachine stateMachine;
private long previousUserMemory;
private long previousRevocableMemory;
public UpdatePeakMemory(QueryStateMachine stateMachine)
{
this.stateMachine = stateMachine;
}
@Override
public synchronized void stateChanged(TaskStatus newStatus)
{
long currentUserMemory = newStatus.getMemoryReservation().toBytes();
long currentRevocableMemory = newStatus.getRevocableMemoryReservation().toBytes();
long currentTotalMemory = currentUserMemory + currentRevocableMemory;
long deltaUserMemoryInBytes = currentUserMemory - previousUserMemory;
long deltaRevocableMemoryInBytes = currentRevocableMemory - previousRevocableMemory;
long deltaTotalMemoryInBytes = currentTotalMemory - (previousUserMemory + previousRevocableMemory);
previousUserMemory = currentUserMemory;
previousRevocableMemory = currentRevocableMemory;
stateMachine.updateMemoryUsage(deltaUserMemoryInBytes, deltaRevocableMemoryInBytes, deltaTotalMemoryInBytes, currentUserMemory, currentRevocableMemory, currentTotalMemory);
}
}
}