A B C D E F G H I L M O P R S T U V W 

A

AbstractTimelineStorageReader - Class in org.apache.hadoop.yarn.server.timelineservice.storage.reader
The base class for reading timeline data from the HBase storage.
AbstractTimelineStorageReader(TimelineReaderContext) - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.reader.AbstractTimelineStorageReader
 
AbstractTimelineStorageReader.FlowContext - Class in org.apache.hadoop.yarn.server.timelineservice.storage.reader
Encapsulates flow context information.
AbstractTimelineStorageReader.FlowContext(String, String, Long) - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.reader.AbstractTimelineStorageReader.FlowContext
 
aggregate(TimelineEntity, TimelineAggregationTrack) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineWriterImpl
 
ApplicationTableRW - Class in org.apache.hadoop.yarn.server.timelineservice.storage.application
Create, read and write to the Application Table.
ApplicationTableRW() - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.application.ApplicationTableRW
 
AppToFlowTableRW - Class in org.apache.hadoop.yarn.server.timelineservice.storage.apptoflow
Create, read and write to the AppToFlow Table.
AppToFlowTableRW() - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.apptoflow.AppToFlowTableRW
 
augmentParams(Configuration, Connection) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.AbstractTimelineStorageReader
Sets certain parameters to defaults if the values are not provided.

B

BaseTableRW<T extends org.apache.hadoop.yarn.server.timelineservice.storage.common.BaseTable<T>> - Class in org.apache.hadoop.yarn.server.timelineservice.storage.common
Implements behavior common to tables used in the timeline service storage.
BaseTableRW(String, String) - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.common.BaseTableRW
 

C

calculateTheClosestNextRowKeyForPrefix(byte[]) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.HBaseTimelineStorageUtils
Given a row key prefix stored in a byte array, return a byte array for its immediate next row key.
close() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.TypedBufferedMutator
 
ColumnRWHelper - Class in org.apache.hadoop.yarn.server.timelineservice.storage.common
A set of utility functions that read or read to a column.
constructFilterListBasedOnFields(Set<String>) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Creates a FilterList based on fields, confs and metrics to retrieve.
constructFilterListBasedOnFilters() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Creates a FilterList based on info, config and metric filters.
createAllTables(Configuration, boolean) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineSchemaCreator
 
createColQualifierPrefix(ColumnPrefix<T>, String) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
 
createEntityTypeReader(TimelineReaderContext) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReaderFactory
Creates a timeline entity type reader that will read all available entity types within the specified context.
createFilterForConfsOrMetricsToRetrieve(TimelineFilterList, ColumnFamily<T>, ColumnPrefix<T>) - Static method in class org.apache.hadoop.yarn.server.timelineservice.reader.filter.TimelineFilterUtils
Create filters for confs or metrics to retrieve.
createFiltersFromColumnQualifiers(ColumnPrefix<T>, Set<String>) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Create a filter list of qualifier filters based on passed set of columns.
createFiltersIfNull() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Create a TimelineEntityFilters object with default values for filters.
createHBaseFilterList(ColumnPrefix<T>, TimelineFilterList) - Static method in class org.apache.hadoop.yarn.server.timelineservice.reader.filter.TimelineFilterUtils
Creates equivalent HBase FilterList from TimelineFilterList while converting different timeline filters(of type TimelineFilter) into their equivalent HBase filters.
createHBaseQualifierFilter(CompareFilter.CompareOp, ColumnPrefix<T>) - Static method in class org.apache.hadoop.yarn.server.timelineservice.reader.filter.TimelineFilterUtils
Create a HBase QualifierFilter for the passed column prefix and compare op.
createHBaseSingleColValueFilter(Column<T>, Object, CompareFilter.CompareOp) - Static method in class org.apache.hadoop.yarn.server.timelineservice.reader.filter.TimelineFilterUtils
Creates a HBase SingleColumnValueFilter with specified column.
createMultipleEntitiesReader(TimelineReaderContext, TimelineEntityFilters, TimelineDataToRetrieve) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReaderFactory
Creates a timeline entity reader instance for reading set of entities with the specified input and predicates.
createSingleColValueFiltersByRange(Column<T>, Object, Object) - Static method in class org.apache.hadoop.yarn.server.timelineservice.reader.filter.TimelineFilterUtils
Create 2 HBase SingleColumnValueFilter filters for the specified value range represented by start and end value and wraps them inside a filter list.
createSingleEntityReader(TimelineReaderContext, TimelineDataToRetrieve) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReaderFactory
Creates a timeline entity reader instance for reading a single entity with the specified input.
createTable(Admin, Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.application.ApplicationTableRW
 
createTable(Admin, Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.apptoflow.AppToFlowTableRW
 
createTable(Admin, Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.BaseTableRW
Used to create the table in HBase.
createTable(Admin, Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.entity.EntityTableRW
 
createTable(Admin, Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.flow.FlowActivityTableRW
 
createTable(Admin, Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.flow.FlowRunTableRW
 
createTable(Admin, Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.subapplication.SubApplicationTableRW
 
createTimelineSchema(String[]) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineSchemaCreator
 

D

DEFAULT_METRICS_MAX_VERSIONS - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.flow.FlowActivityTableRW
default max number of versions.
DEFAULT_METRICS_MAX_VERSIONS - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.flow.FlowRunTableRW
default max number of versions.
DEFAULT_TABLE_NAME - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.entity.EntityTableRW
default value for entity table name.
DEFAULT_TABLE_NAME - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.flow.FlowActivityTableRW
default value for flowactivity table name.
DEFAULT_TABLE_NAME - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.flow.FlowRunTableRW
default value for flowrun table name.
DEFAULT_TABLE_NAME - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.subapplication.SubApplicationTableRW
default value for subapplication table name.
defaultAugmentParams(Configuration, Connection) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.AbstractTimelineStorageReader
Default behavior for all timeline readers to augment parameters.

E

EntityTableRW - Class in org.apache.hadoop.yarn.server.timelineservice.storage.entity
Create, read and write to the Entity Table.
EntityTableRW() - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.entity.EntityTableRW
 
EntityTypeReader - Class in org.apache.hadoop.yarn.server.timelineservice.storage.reader
Timeline entity reader for listing all available entity types given one reader context.
EntityTypeReader(TimelineReaderContext) - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.reader.EntityTypeReader
 

F

fetchColumnsFromFilterList(TimelineFilterList) - Static method in class org.apache.hadoop.yarn.server.timelineservice.reader.filter.TimelineFilterUtils
Fetch columns from filter list containing exists and multivalue equality filters.
FlowActivityTableRW - Class in org.apache.hadoop.yarn.server.timelineservice.storage.flow
Create, read and write to the FlowActivity Table.
FlowActivityTableRW() - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.flow.FlowActivityTableRW
 
FlowRunTableRW - Class in org.apache.hadoop.yarn.server.timelineservice.storage.flow
Create, read and write to the FlowRun table.
FlowRunTableRW() - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.flow.FlowRunTableRW
 
flush() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.TypedBufferedMutator
 
flush() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineWriterImpl
 

G

getConfiguration() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.TypedBufferedMutator
 
getContext() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.AbstractTimelineStorageReader
 
getDataToRetrieve() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
 
getEntities(TimelineReaderContext, TimelineEntityFilters, TimelineDataToRetrieve) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineReaderImpl
 
getEntity(TimelineReaderContext, TimelineDataToRetrieve) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineReaderImpl
 
getEntityTypes(TimelineReaderContext) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineReaderImpl
 
getFilters() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
 
getFlowName() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.AbstractTimelineStorageReader.FlowContext
 
getFlowRunId() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.AbstractTimelineStorageReader.FlowContext
 
getName() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.TypedBufferedMutator
 
getResult(Configuration, Connection, Get) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.BaseTableRW
 
getResult(Configuration, Connection, FilterList) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Fetches a Result instance for a single-entity read.
getResults(Configuration, Connection, FilterList) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Fetches a ResultScanner for a multi-entity read.
getResultScanner(Configuration, Connection, Scan) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.BaseTableRW
 
getTable() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Returns the main table to be used by the entity reader.
getTableMutator(Configuration, Connection) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.BaseTableRW
Used to create a type-safe mutator for this table.
getTableName(Configuration, String) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.BaseTableRW
Get the table name for the input table.
getTableName(Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.BaseTableRW
Get the table name for this table.
getTableName(Configuration, String, String) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.BaseTableRW
Get the table name based on the input config parameters.
getTimelineServiceHBaseConf(Configuration) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.HBaseTimelineStorageUtils
 
getUserId() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.AbstractTimelineStorageReader.FlowContext
 
getUsernameSplits() - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.TimelineHBaseSchemaConstants
 
getWriteBufferSize() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.TypedBufferedMutator
 

H

hasField(EnumSet<TimelineReader.Field>, TimelineReader.Field) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Check if we have a certain field amongst fields to retrieve.
HBaseTimelineReaderImpl - Class in org.apache.hadoop.yarn.server.timelineservice.storage
HBase based implementation for TimelineReader.
HBaseTimelineReaderImpl() - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineReaderImpl
 
HBaseTimelineSchemaCreator - Class in org.apache.hadoop.yarn.server.timelineservice.storage
This creates the schema for a hbase based backend for storing application timeline information.
HBaseTimelineSchemaCreator() - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineSchemaCreator
 
HBaseTimelineStorageUtils - Class in org.apache.hadoop.yarn.server.timelineservice.storage.common
A bunch of utility functions used in HBase TimelineService backend.
HBaseTimelineWriterImpl - Class in org.apache.hadoop.yarn.server.timelineservice.storage
This implements a hbase based backend for storing the timeline entity information.
HBaseTimelineWriterImpl() - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineWriterImpl
 

I

isSingleEntityRead() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Checks whether the reader has been created to fetch single entity or multiple entities.

L

lookupFlowContext(AppToFlowRowKey, String, Configuration, Connection) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.AbstractTimelineStorageReader
Looks up flow context from AppToFlow table.

M

MILLIS_ONE_DAY - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.common.HBaseTimelineStorageUtils
milliseconds in one day.
mutate(Mutation) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.TypedBufferedMutator
 
mutate(List<? extends Mutation>) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.TypedBufferedMutator
 

O

org.apache.hadoop.yarn.server.timelineservice.reader.filter - package org.apache.hadoop.yarn.server.timelineservice.reader.filter
Package org.apache.hadoop.server.timelineservice.reader.filter stores timeline filter implementations.
org.apache.hadoop.yarn.server.timelineservice.storage - package org.apache.hadoop.yarn.server.timelineservice.storage
Package org.apache.hadoop.yarn.server.timelineservice.storage contains classes which define and implement reading and writing to backend storage.
org.apache.hadoop.yarn.server.timelineservice.storage.application - package org.apache.hadoop.yarn.server.timelineservice.storage.application
Package org.apache.hadoop.yarn.server.timelineservice.storage.application contains classes related to implementation for application table.
org.apache.hadoop.yarn.server.timelineservice.storage.apptoflow - package org.apache.hadoop.yarn.server.timelineservice.storage.apptoflow
Package org.apache.hadoop.yarn.server.timelineservice.storage.apptoflow contains classes related to implementation for app to flow table.
org.apache.hadoop.yarn.server.timelineservice.storage.common - package org.apache.hadoop.yarn.server.timelineservice.storage.common
Package org.apache.hadoop.yarn.server.timelineservice.storage contains classes which define and implement reading and writing to backend storage.
org.apache.hadoop.yarn.server.timelineservice.storage.entity - package org.apache.hadoop.yarn.server.timelineservice.storage.entity
Package org.apache.hadoop.yarn.server.timelineservice.storage.entity contains classes related to implementation for entity table.
org.apache.hadoop.yarn.server.timelineservice.storage.flow - package org.apache.hadoop.yarn.server.timelineservice.storage.flow
Package org.apache.hadoop.yarn.server.timelineservice.storage.flow contains classes related to implementation for flow related tables, viz.
org.apache.hadoop.yarn.server.timelineservice.storage.reader - package org.apache.hadoop.yarn.server.timelineservice.storage.reader
Package org.apache.hadoop.yarn.server.timelineservice.storage.reader contains classes used to read entities from backend based on query type.
org.apache.hadoop.yarn.server.timelineservice.storage.subapplication - package org.apache.hadoop.yarn.server.timelineservice.storage.subapplication
Package org.apache.hadoop.yarn.server.timelineservice.storage.subapplication contains classes related to implementation for subapplication table.

P

parseEntity(Result) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Parses the result retrieved from HBase backend and convert it into a TimelineEntity object.

R

readEntities(Configuration, Connection) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Reads and deserializes a set of timeline entities from the HBase storage.
readEntity(Configuration, Connection) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Reads and deserializes a single timeline entity from the HBase storage.
readEntityTypes(Configuration, Connection) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.EntityTypeReader
Reads a set of timeline entity types from the HBase storage for the given context.
readEvents(TimelineEntity, Result, ColumnPrefix<T>) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Read events from the entity table or the application table.
readMetrics(TimelineEntity, Result, ColumnPrefix<?>) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Helper method for reading and deserializing TimelineMetric objects using the specified column prefix.
readRelationship(TimelineEntity, Result, ColumnPrefix<T>, boolean) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Helper method for reading relationship.
readResult(Result, byte[], byte[], ValueConverter) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.ColumnRWHelper
Get the latest version of this specified column.
readResult(Result, Column<?>) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.ColumnRWHelper
Get the latest version of this specified column.
readResult(Result, ColumnPrefix<?>, String) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.ColumnRWHelper
Get the latest version of this specified column.
readResults(Result, ColumnPrefix<?>, KeyConverter<K>) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.ColumnRWHelper
 
readResults(Result, byte[], byte[], KeyConverter<K>, ValueConverter) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.ColumnRWHelper
 
readResultsWithTimestamps(Result, ColumnPrefix<?>, KeyConverter<K>) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.ColumnRWHelper
 
readResultsWithTimestamps(Result, byte[], byte[], KeyConverter<K>, ValueConverter, boolean) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.ColumnRWHelper
 

S

serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineReaderImpl
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineWriterImpl
initializes the hbase connection to write to the entity table.
serviceStop() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineReaderImpl
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineWriterImpl
close the hbase connections The close APIs perform flushing and release any resources held.
setMetricsTimeRange(Query, byte[], long, long) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.HBaseTimelineStorageUtils
 
setMetricsTTL(int, Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.application.ApplicationTableRW
 
setMetricsTTL(int, Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.entity.EntityTableRW
 
setMetricsTTL(int, Configuration) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.subapplication.SubApplicationTableRW
 
setTable(BaseTableRW<?>) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
 
store(byte[], TypedBufferedMutator<?>, Column<?>, Long, Object, Attribute...) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.ColumnRWHelper
Sends a Mutation to the table.
store(byte[], TypedBufferedMutator<?>, byte[], byte[], Long, boolean, Object, ValueConverter, Attribute...) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.ColumnRWHelper
Sends a Mutation to the table.
store(byte[], TypedBufferedMutator<?>, ColumnPrefix<?>, byte[], Long, Object, Attribute...) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.ColumnRWHelper
Sends a Mutation to the table.
store(byte[], TypedBufferedMutator<?>, ColumnPrefix<?>, String, Long, Object, Attribute...) - Static method in class org.apache.hadoop.yarn.server.timelineservice.storage.common.ColumnRWHelper
Sends a Mutation to the table.
SubApplicationTableRW - Class in org.apache.hadoop.yarn.server.timelineservice.storage.subapplication
Create, read and write to the SubApplication table.
SubApplicationTableRW() - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.subapplication.SubApplicationTableRW
 

T

TABLE_NAME_CONF_NAME - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.application.ApplicationTableRW
config param name that specifies the application table name.
TABLE_NAME_CONF_NAME - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.apptoflow.AppToFlowTableRW
config param name that specifies the app_flow table name.
TABLE_NAME_CONF_NAME - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.entity.EntityTableRW
config param name that specifies the entity table name.
TABLE_NAME_CONF_NAME - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.flow.FlowActivityTableRW
config param name that specifies the flowactivity table name.
TABLE_NAME_CONF_NAME - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.flow.FlowRunTableRW
config param name that specifies the flowrun table name.
TABLE_NAME_CONF_NAME - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.subapplication.SubApplicationTableRW
config param name that specifies the subapplication table name.
TimelineEntityReader - Class in org.apache.hadoop.yarn.server.timelineservice.storage.reader
The base class for reading and deserializing timeline entities from the HBase storage.
TimelineEntityReader(TimelineReaderContext, TimelineEntityFilters, TimelineDataToRetrieve) - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Instantiates a reader for multiple-entity reads.
TimelineEntityReader(TimelineReaderContext, TimelineDataToRetrieve) - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.reader.TimelineEntityReader
Instantiates a reader for single-entity reads.
TimelineEntityReaderFactory - Class in org.apache.hadoop.yarn.server.timelineservice.storage.reader
Factory methods for instantiating a timeline entity reader.
TimelineFilterUtils - Class in org.apache.hadoop.yarn.server.timelineservice.reader.filter
Set of utility methods used by timeline filter classes.
TimelineHBaseSchemaConstants - Class in org.apache.hadoop.yarn.server.timelineservice.storage.common
contains the constants used in the context of schema accesses for TimelineEntity information.
TypedBufferedMutator<T extends org.apache.hadoop.yarn.server.timelineservice.storage.common.BaseTable<T>> - Class in org.apache.hadoop.yarn.server.timelineservice.storage.common
To be used to wrap an actual BufferedMutator in a type safe manner.
TypedBufferedMutator(BufferedMutator) - Constructor for class org.apache.hadoop.yarn.server.timelineservice.storage.common.TypedBufferedMutator
 

U

USERNAME_SPLIT_KEY_PREFIX_LENGTH - Static variable in class org.apache.hadoop.yarn.server.timelineservice.storage.common.TimelineHBaseSchemaConstants
The length at which keys auto-split.

V

validateParams() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.AbstractTimelineStorageReader
Validates the required parameters to read the entities.
validateParams() - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.reader.EntityTypeReader
 

W

write(TimelineCollectorContext, TimelineEntities, UserGroupInformation) - Method in class org.apache.hadoop.yarn.server.timelineservice.storage.HBaseTimelineWriterImpl
Stores the entire information in TimelineEntities to the timeline store.
A B C D E F G H I L M O P R S T U V W 

Copyright © 2022 Apache Software Foundation. All rights reserved.