| Package | Description | 
|---|---|
| org.apache.hadoop.io | Generic i/o code for use when reading and writing data to the network,
to databases, and to files. | 
| org.apache.hadoop.mapred | |
| org.apache.hadoop.mapred.lib | |
| org.apache.hadoop.mapred.lib.aggregate | |
| org.apache.hadoop.mapreduce | |
| org.apache.hadoop.mapreduce.lib.aggregate | |
| org.apache.hadoop.mapreduce.lib.fieldsel | |
| org.apache.hadoop.mapreduce.lib.input | |
| org.apache.hadoop.mapreduce.lib.map | |
| org.apache.hadoop.mapreduce.security | |
| org.apache.hadoop.yarn.client | |
| org.apache.hadoop.yarn.client.api | Licensed to the Apache Software Foundation (ASF) under one
 or more contributor license agreements. | 
| org.apache.hadoop.yarn.security | |
| org.apache.hadoop.yarn.security.client | |
| org.apache.hadoop.yarn.util.timeline | 
| Modifier and Type | Method and Description | 
|---|---|
| void | Text. set(Text other)copy a text. | 
| Constructor and Description | 
|---|
| Text(Text utf8)Construct from another text. | 
| Modifier and Type | Method and Description | 
|---|---|
| Text | SequenceFileAsTextRecordReader. createKey() | 
| Text | KeyValueLineRecordReader. createKey() | 
| Text | SequenceFileAsTextRecordReader. createValue() | 
| Text | KeyValueLineRecordReader. createValue() | 
| Modifier and Type | Method and Description | 
|---|---|
| RecordReader<LongWritable,Text> | TextInputFormat. getRecordReader(InputSplit genericSplit,
                              JobConf job,
                              Reporter reporter) | 
| RecordReader<Text,Text> | SequenceFileAsTextInputFormat. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter) | 
| RecordReader<Text,Text> | SequenceFileAsTextInputFormat. getRecordReader(InputSplit split,
                              JobConf job,
                              Reporter reporter) | 
| RecordReader<Text,Text> | KeyValueTextInputFormat. getRecordReader(InputSplit genericSplit,
                              JobConf job,
                              Reporter reporter) | 
| RecordReader<Text,Text> | KeyValueTextInputFormat. getRecordReader(InputSplit genericSplit,
                              JobConf job,
                              Reporter reporter) | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> | JobClient. getDelegationToken(Text renewer)Get a delegation token for the user from the JobTracker. | 
| boolean | SequenceFileAsTextRecordReader. next(Text key,
        Text value)Read key/value pair in a line. | 
| boolean | KeyValueLineRecordReader. next(Text key,
        Text value)Read key/value pair in a line. | 
| Modifier and Type | Method and Description | 
|---|---|
| RecordReader<LongWritable,Text> | CombineTextInputFormat. getRecordReader(InputSplit split,
                              JobConf conf,
                              Reporter reporter) | 
| RecordReader<LongWritable,Text> | NLineInputFormat. getRecordReader(InputSplit genericSplit,
                              JobConf job,
                              Reporter reporter) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RegexMapper. map(K key,
      Text value,
      OutputCollector<Text,LongWritable> output,
      Reporter reporter) | 
| void | TokenCountMapper. map(K key,
      Text value,
      OutputCollector<Text,LongWritable> output,
      Reporter reporter) | 
| void | FieldSelectionMapReduce. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RegexMapper. map(K key,
      Text value,
      OutputCollector<Text,LongWritable> output,
      Reporter reporter) | 
| void | TokenCountMapper. map(K key,
      Text value,
      OutputCollector<Text,LongWritable> output,
      Reporter reporter) | 
| void | FieldSelectionMapReduce. map(K key,
      V val,
      OutputCollector<Text,Text> output,
      Reporter reporter)The identify function. | 
| void | FieldSelectionMapReduce. map(K key,
      V val,
      OutputCollector<Text,Text> output,
      Reporter reporter)The identify function. | 
| void | FieldSelectionMapReduce. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter) | 
| void | FieldSelectionMapReduce. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter) | 
| void | FieldSelectionMapReduce. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter) | 
| Modifier and Type | Field and Description | 
|---|---|
| static Text | ValueAggregatorDescriptor. ONE | 
| Modifier and Type | Method and Description | 
|---|---|
| static Map.Entry<Text,Text> | ValueAggregatorBaseDescriptor. generateEntry(String type,
                          String id,
                          Text val) | 
| static Map.Entry<Text,Text> | ValueAggregatorBaseDescriptor. generateEntry(String type,
                          String id,
                          Text val) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Map.Entry<Text,Text> | ValueAggregatorBaseDescriptor. generateEntry(String type,
                          String id,
                          Text val) | 
| void | ValueAggregatorCombiner. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter)Combines values for a given key. | 
| void | ValueAggregatorReducer. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter) | 
| void | ValueAggregatorMapper. reduce(Text arg0,
            Iterator<Text> arg1,
            OutputCollector<Text,Text> arg2,
            Reporter arg3)Do nothing. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ValueAggregatorCombiner. map(K1 arg0,
      V1 arg1,
      OutputCollector<Text,Text> arg2,
      Reporter arg3)Do nothing. | 
| void | ValueAggregatorCombiner. map(K1 arg0,
      V1 arg1,
      OutputCollector<Text,Text> arg2,
      Reporter arg3)Do nothing. | 
| void | ValueAggregatorReducer. map(K1 arg0,
      V1 arg1,
      OutputCollector<Text,Text> arg2,
      Reporter arg3)Do nothing. | 
| void | ValueAggregatorReducer. map(K1 arg0,
      V1 arg1,
      OutputCollector<Text,Text> arg2,
      Reporter arg3)Do nothing. | 
| void | ValueAggregatorMapper. map(K1 key,
      V1 value,
      OutputCollector<Text,Text> output,
      Reporter reporter)the map function. | 
| void | ValueAggregatorMapper. map(K1 key,
      V1 value,
      OutputCollector<Text,Text> output,
      Reporter reporter)the map function. | 
| void | ValueAggregatorCombiner. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter)Combines values for a given key. | 
| void | ValueAggregatorCombiner. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter)Combines values for a given key. | 
| void | ValueAggregatorCombiner. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter)Combines values for a given key. | 
| void | ValueAggregatorReducer. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter) | 
| void | ValueAggregatorReducer. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter) | 
| void | ValueAggregatorReducer. reduce(Text key,
            Iterator<Text> values,
            OutputCollector<Text,Text> output,
            Reporter reporter) | 
| void | ValueAggregatorMapper. reduce(Text arg0,
            Iterator<Text> arg1,
            OutputCollector<Text,Text> arg2,
            Reporter arg3)Do nothing. | 
| void | ValueAggregatorMapper. reduce(Text arg0,
            Iterator<Text> arg1,
            OutputCollector<Text,Text> arg2,
            Reporter arg3)Do nothing. | 
| void | ValueAggregatorMapper. reduce(Text arg0,
            Iterator<Text> arg1,
            OutputCollector<Text,Text> arg2,
            Reporter arg3)Do nothing. | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> | Cluster. getDelegationToken(Text renewer)Get a delegation token for the user from the JobTracker. | 
| Modifier and Type | Field and Description | 
|---|---|
| static Text | ValueAggregatorDescriptor. ONE | 
| Modifier and Type | Method and Description | 
|---|---|
| static Map.Entry<Text,Text> | ValueAggregatorBaseDescriptor. generateEntry(String type,
                          String id,
                          Text val) | 
| static Map.Entry<Text,Text> | ValueAggregatorBaseDescriptor. generateEntry(String type,
                          String id,
                          Text val) | 
| ArrayList<Map.Entry<Text,Text>> | ValueAggregatorBaseDescriptor. generateKeyValPairs(Object key,
                                      Object val)Generate 1 or 2 aggregation-id/value pairs for the given key/value pair. | 
| ArrayList<Map.Entry<Text,Text>> | ValueAggregatorBaseDescriptor. generateKeyValPairs(Object key,
                                      Object val)Generate 1 or 2 aggregation-id/value pairs for the given key/value pair. | 
| ArrayList<Map.Entry<Text,Text>> | UserDefinedValueAggregatorDescriptor. generateKeyValPairs(Object key,
                                      Object val)Generate a list of aggregation-id/value pairs for the given 
   key/value pairs by delegating the invocation to the real object. | 
| ArrayList<Map.Entry<Text,Text>> | UserDefinedValueAggregatorDescriptor. generateKeyValPairs(Object key,
                                      Object val)Generate a list of aggregation-id/value pairs for the given 
   key/value pairs by delegating the invocation to the real object. | 
| ArrayList<Map.Entry<Text,Text>> | ValueAggregatorDescriptor. generateKeyValPairs(Object key,
                                      Object val)Generate a list of aggregation-id/value pairs for 
 the given key/value pair. | 
| ArrayList<Map.Entry<Text,Text>> | ValueAggregatorDescriptor. generateKeyValPairs(Object key,
                                      Object val)Generate a list of aggregation-id/value pairs for 
 the given key/value pair. | 
| Modifier and Type | Method and Description | 
|---|---|
| static Map.Entry<Text,Text> | ValueAggregatorBaseDescriptor. generateEntry(String type,
                          String id,
                          Text val) | 
| void | ValueAggregatorCombiner. reduce(Text key,
            Iterable<Text> values,
            org.apache.hadoop.mapreduce.Reducer.Context context)Combines values for a given key. | 
| void | ValueAggregatorReducer. reduce(Text key,
            Iterable<Text> values,
            org.apache.hadoop.mapreduce.Reducer.Context context) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ValueAggregatorCombiner. reduce(Text key,
            Iterable<Text> values,
            org.apache.hadoop.mapreduce.Reducer.Context context)Combines values for a given key. | 
| void | ValueAggregatorReducer. reduce(Text key,
            Iterable<Text> values,
            org.apache.hadoop.mapreduce.Reducer.Context context) | 
| Modifier and Type | Field and Description | 
|---|---|
| static Text | FieldSelectionHelper. emptyText | 
| Modifier and Type | Method and Description | 
|---|---|
| Text | FieldSelectionHelper. getKey() | 
| Text | FieldSelectionHelper. getValue() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FieldSelectionReducer. reduce(Text key,
            Iterable<Text> values,
            org.apache.hadoop.mapreduce.Reducer.Context context) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FieldSelectionReducer. reduce(Text key,
            Iterable<Text> values,
            org.apache.hadoop.mapreduce.Reducer.Context context) | 
| Constructor and Description | 
|---|
| FieldSelectionHelper(Text key,
                                        Text val) | 
| Modifier and Type | Method and Description | 
|---|---|
| Text | SequenceFileAsTextRecordReader. getCurrentKey() | 
| Text | KeyValueLineRecordReader. getCurrentKey() | 
| Text | SequenceFileAsTextRecordReader. getCurrentValue() | 
| Text | KeyValueLineRecordReader. getCurrentValue() | 
| Modifier and Type | Method and Description | 
|---|---|
| RecordReader<LongWritable,Text> | TextInputFormat. createRecordReader(InputSplit split,
                                    TaskAttemptContext context) | 
| RecordReader<Text,Text> | SequenceFileAsTextInputFormat. createRecordReader(InputSplit split,
                                    TaskAttemptContext context) | 
| RecordReader<Text,Text> | SequenceFileAsTextInputFormat. createRecordReader(InputSplit split,
                                    TaskAttemptContext context) | 
| RecordReader<Text,Text> | KeyValueTextInputFormat. createRecordReader(InputSplit genericSplit,
                                    TaskAttemptContext context) | 
| RecordReader<Text,Text> | KeyValueTextInputFormat. createRecordReader(InputSplit genericSplit,
                                    TaskAttemptContext context) | 
| RecordReader<LongWritable,Text> | CombineTextInputFormat. createRecordReader(InputSplit split,
                                    TaskAttemptContext context) | 
| RecordReader<LongWritable,Text> | NLineInputFormat. createRecordReader(InputSplit genericSplit,
                                    TaskAttemptContext context) | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | KeyValueLineRecordReader. setKeyValue(Text key,
                      Text value,
                      byte[] line,
                      int lineLen,
                      int pos) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RegexMapper. map(K key,
      Text value,
      org.apache.hadoop.mapreduce.Mapper.Context context) | 
| void | TokenCounterMapper. map(Object key,
      Text value,
      org.apache.hadoop.mapreduce.Mapper.Context context) | 
| Modifier and Type | Method and Description | 
|---|---|
| static byte[] | TokenCache. getSecretKey(org.apache.hadoop.security.Credentials credentials,
                        Text alias)auxiliary method to get user's secret keys.. | 
| Modifier and Type | Method and Description | 
|---|---|
| static Text | ClientRMProxy. getAMRMTokenService(Configuration conf) | 
| static Text | ClientRMProxy. getRMDelegationTokenService(Configuration conf)Get the token service name to be used for RMDelegationToken. | 
| static Text | ClientRMProxy. getTokenService(Configuration conf,
                              String address,
                              String defaultAddr,
                              int defaultPort) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract Token | YarnClient. getRMDelegationToken(Text renewer)
 Get a delegation token so as to be able to talk to YARN using those tokens. | 
| Modifier and Type | Field and Description | 
|---|---|
| static Text | NMTokenIdentifier. KIND | 
| static Text | ContainerTokenIdentifier. KIND | 
| static Text | AMRMTokenIdentifier. KIND_NAME | 
| Modifier and Type | Method and Description | 
|---|---|
| Text | NMTokenIdentifier. getKind() | 
| Text | ContainerTokenIdentifier. getKind() | 
| Text | AMRMTokenIdentifier. getKind() | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.security.token.Token<ContainerTokenIdentifier> | ContainerTokenSelector. selectToken(Text service,
                      Collection<org.apache.hadoop.security.token.Token<? extends org.apache.hadoop.security.token.TokenIdentifier>> tokens) | 
| org.apache.hadoop.security.token.Token<AMRMTokenIdentifier> | AMRMTokenSelector. selectToken(Text service,
                      Collection<org.apache.hadoop.security.token.Token<? extends org.apache.hadoop.security.token.TokenIdentifier>> tokens) | 
| Modifier and Type | Field and Description | 
|---|---|
| static Text | ClientToAMTokenIdentifier. KIND_NAME | 
| static Text | TimelineDelegationTokenIdentifier. KIND_NAME | 
| static Text | RMDelegationTokenIdentifier. KIND_NAME | 
| Modifier and Type | Method and Description | 
|---|---|
| Text | ClientToAMTokenIdentifier. getKind() | 
| Text | TimelineDelegationTokenIdentifier. getKind() | 
| Text | RMDelegationTokenIdentifier. getKind() | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.security.token.Token<TimelineDelegationTokenIdentifier> | TimelineDelegationTokenSelector. selectToken(Text service,
                      Collection<org.apache.hadoop.security.token.Token<? extends org.apache.hadoop.security.token.TokenIdentifier>> tokens) | 
| org.apache.hadoop.security.token.Token<RMDelegationTokenIdentifier> | RMDelegationTokenSelector. selectToken(Text service,
                      Collection<org.apache.hadoop.security.token.Token<? extends org.apache.hadoop.security.token.TokenIdentifier>> tokens) | 
| Constructor and Description | 
|---|
| RMDelegationTokenIdentifier(Text owner,
                                                      Text renewer,
                                                      Text realUser)Create a new delegation token identifier | 
| TimelineDelegationTokenIdentifier(Text owner,
                                                                  Text renewer,
                                                                  Text realUser)Create a new timeline delegation token identifier | 
| Modifier and Type | Method and Description | 
|---|---|
| static Text | TimelineUtils. buildTimelineTokenService(Configuration conf) | 
Copyright © 2016 Apache Software Foundation. All Rights Reserved.