public class WorkloadManager extends TezSessionPoolSession.AbstractTriggerValidator implements TezSessionPoolSession.Manager, WorkloadManagerMxBean
| Modifier and Type | Class and Description |
|---|---|
static class |
WorkloadManager.NoPoolMappingException |
| Modifier and Type | Field and Description |
|---|---|
protected Thread |
wmThread
The master thread the processes the events from EventState.
|
| Modifier and Type | Method and Description |
|---|---|
void |
closeAndReopenExpiredSession(org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolSession session) |
static WorkloadManager |
create(String yarnQueue,
HiveConf conf,
org.apache.hadoop.hive.metastore.api.WMFullResourcePlan plan)
Called once, when HS2 initializes.
|
protected WmTezSession |
createSessionObject(String sessionId,
HiveConf conf) |
void |
destroy(TezSessionState session) |
protected HiveConf |
getConf() |
org.apache.hadoop.hive.ql.exec.tez.SessionExpirationTracker |
getExpirationTracker() |
static WorkloadManager |
getInstance() |
WmTezSession |
getSession(TezSessionState session,
UserPoolMapping.MappingInput input,
HiveConf conf) |
WmTezSession |
getSession(TezSessionState session,
UserPoolMapping.MappingInput input,
HiveConf conf,
WmContext wmContext) |
List<String> |
getWmStateDescription() |
void |
notifyInitializationCompleted(org.apache.hadoop.hive.ql.exec.tez.WorkloadManager.SessionInitContext initCtx) |
void |
notifyOfClusterStateChange() |
void |
notifyOfInconsistentAllocation(WmTezSession session) |
void |
registerOpenSession(org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolSession session)
Called by TezSessionPoolSession when opened.
|
TezSessionState |
reopen(TezSessionState session) |
void |
returnAfterUse(org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolSession session) |
void |
start() |
void |
stop() |
void |
unregisterOpenSession(org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolSession session)
Called by TezSessionPoolSession when closed.
|
com.google.common.util.concurrent.ListenableFuture<Boolean> |
updateResourcePlanAsync(org.apache.hadoop.hive.metastore.api.WMFullResourcePlan plan) |
protected final Thread wmThread
public static WorkloadManager getInstance()
public static WorkloadManager create(String yarnQueue, HiveConf conf, org.apache.hadoop.hive.metastore.api.WMFullResourcePlan plan) throws ExecutionException, InterruptedException
public com.google.common.util.concurrent.ListenableFuture<Boolean> updateResourcePlanAsync(org.apache.hadoop.hive.metastore.api.WMFullResourcePlan plan)
public WmTezSession getSession(TezSessionState session, UserPoolMapping.MappingInput input, HiveConf conf) throws Exception
Exceptionpublic WmTezSession getSession(TezSessionState session, UserPoolMapping.MappingInput input, HiveConf conf, WmContext wmContext) throws Exception
Exceptionpublic void destroy(TezSessionState session) throws Exception
destroy in interface TezSessionPoolSession.ManagerExceptionpublic void returnAfterUse(org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolSession session)
throws Exception
returnAfterUse in interface TezSessionPoolSession.ManagerExceptionpublic void notifyOfInconsistentAllocation(WmTezSession session)
public void notifyOfClusterStateChange()
public List<String> getWmStateDescription()
getWmStateDescription in interface WorkloadManagerMxBeanpublic void notifyInitializationCompleted(org.apache.hadoop.hive.ql.exec.tez.WorkloadManager.SessionInitContext initCtx)
public TezSessionState reopen(TezSessionState session) throws Exception
reopen in interface TezSessionPoolSession.ManagerExceptionpublic void closeAndReopenExpiredSession(org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolSession session)
throws Exception
Exceptionprotected WmTezSession createSessionObject(String sessionId, HiveConf conf)
public void registerOpenSession(org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolSession session)
registerOpenSession in interface TezSessionPoolSession.Managerpublic void unregisterOpenSession(org.apache.hadoop.hive.ql.exec.tez.TezSessionPoolSession session)
unregisterOpenSession in interface TezSessionPoolSession.Managerpublic org.apache.hadoop.hive.ql.exec.tez.SessionExpirationTracker getExpirationTracker()
protected final HiveConf getConf()
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.