Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

A

abortJob(JobContext, JobStatus.State) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
abortJob(JobContext, JobStatus.State) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigOutputFormatTez.PigOutputCommitterTez
 
abortTask(TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
ABS - Class in org.apache.pig.builtin
ABS implements a binding to the Java function Math.abs(double) for computing the absolute value of the argument.
ABS() - Constructor for class org.apache.pig.builtin.ABS
 
ABS - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use ABS
ABS() - Constructor for class org.apache.pig.piggybank.evaluation.math.ABS
Deprecated.
 
AbstractAccumuloStorage - Class in org.apache.pig.backend.hadoop.accumulo
A LoadStoreFunc for retrieving data from and storing data to Accumulo A Key/Val pair will be returned as tuples: (key, colfam, colqual, colvis, timestamp, value).
AbstractAccumuloStorage(String, String) - Constructor for class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
AbstractTuple - Class in org.apache.pig.data
This class provides a convenient base for Tuple implementations.
AbstractTuple() - Constructor for class org.apache.pig.data.AbstractTuple
 
accept(PlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternNode
 
accept(Path) - Method in class org.apache.pig.builtin.OrcStorage.NonEmptyOrcFileFilter
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.AddExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.AndExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.BinCondExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.CastExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.ConstantExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.DivideExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.EqualExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.GreaterThanEqualExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.GreaterThanExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.IsNullExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.LessThanEqualExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.LessThanExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.MapLookupExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.ModExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.MultiplyExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.NegativeExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.NotEqualExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.NotExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.OrExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.RegexExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.ScalarExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.SubtractExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOCross
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOCube
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LODistinct
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOFilter
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOForEach
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOInnerLoad
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOLimit
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LONative
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LORank
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOSplit
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOSplitOutput
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOStream
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.logical.relational.LOUnion
 
accept(PlanVisitor) - Method in class org.apache.pig.newplan.Operator
Accept a visitor at this node in the graph.
accept(PlanVisitor) - Method in class org.apache.pig.tools.pigstats.JobStats
 
accept(PlanVisitor) - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
accept(PlanVisitor) - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
accept(PlanVisitor) - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
accept(PlanVisitor) - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
accepts(Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.LocalExecType
 
accepts(Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRExecType
 
accepts(Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkExecType
 
accepts(Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkLocalExecType
 
accepts(Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezExecType
 
accepts(Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezLocalExecType
 
accepts(Properties) - Method in interface org.apache.pig.ExecType
An ExecType is selected based off the Properties for the given script.
accepts(String, String) - Method in enum org.apache.pig.scripting.ScriptEngine.SupportedScriptLang
If other discovery mechanisms come up they can also override accepts()
accumChild(List<ExpressionOperator>, byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
Drive all the UDFs in accumulative mode
accumulate(Tuple) - Method in interface org.apache.pig.Accumulator
Pass tuples to the UDF.
accumulate(Tuple) - Method in class org.apache.pig.AccumulatorEvalFunc
 
accumulate(Tuple) - Method in class org.apache.pig.AlgebraicEvalFunc
This is the free accumulate implementation based on the static classes provided by the Algebraic static classes.
accumulate(Tuple) - Method in class org.apache.pig.builtin.AlgebraicBigDecimalMathBase
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.AlgebraicBigIntegerMathBase
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.AlgebraicByteArrayMathBase
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.AlgebraicDoubleMathBase
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.AlgebraicFloatMathBase
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.AlgebraicIntMathBase
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.AlgebraicLongMathBase
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.AVG
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.BigDecimalAvg
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.BigIntegerAvg
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.COUNT
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.COUNT_STAR
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.DateTimeMax
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.DateTimeMin
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.DoubleAvg
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.FloatAvg
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.IntAvg
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.LongAvg
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.StringMax
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.StringMin
 
accumulate(Tuple) - Method in class org.apache.pig.builtin.TOP
 
accumulate(Tuple) - Method in class org.apache.pig.IteratingAccumulatorEvalFunc
 
accumulate(Tuple) - Method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
 
accumulate(Tuple) - Method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField
Accumulate implementation - calls max() on the incoming tuple set including intermediate tuple if already exists
accumulate(Tuple) - Method in class org.apache.pig.scripting.groovy.GroovyAccumulatorEvalFunc
 
accumulate(Tuple) - Method in class org.apache.pig.scripting.jruby.JrubyAccumulatorEvalFunc
This uses the "exec" method required of AccumulatorPigUdf Ruby classes.
accumulateStats(JobControl) - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
Updates the statistics after a patch of jobs is done
accumulateStats(TezJob) - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Updates the statistics after a DAG is finished.
accumulateStats(TezJob) - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
Updates the statistics after a DAG is finished.
accumulateStats(VertexStatus, int) - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
AccumulativeBag - Class in org.apache.pig.data
 
AccumulativeBag(AccumulativeTupleBuffer, int) - Constructor for class org.apache.pig.data.AccumulativeBag
 
AccumulativeTupleBuffer - Interface in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
This interface is used during Reduce phrase to process tuples in batch mode.
Accumulator<T> - Interface in org.apache.pig
An interface that allows UDFs that take a bag to accumulate tuples in chunks rather than take the whole set at once.
AccumulatorAccumulate - Annotation Type in org.apache.pig.scripting.groovy
This annotation is to be used on a Groovy method which is part of an Accumulator UDF to indicate that it will act as the 'accumulate' method of the UDF.
AccumulatorCleanup - Annotation Type in org.apache.pig.scripting.groovy
This annotation is to be used on a Groovy method which is part of an Accumulator UDF to indicate that it will act as the 'cleanup' method of the UDF.
AccumulatorEvalFunc<T> - Class in org.apache.pig
This class is used to provide a free implementation of the EvalFunc exec function given implementation of the Accumulator interface.
AccumulatorEvalFunc() - Constructor for class org.apache.pig.AccumulatorEvalFunc
 
AccumulatorGetValue - Annotation Type in org.apache.pig.scripting.groovy
This annotation is to be used on a Groovy method which is part of an Accumulator UDF to indicate that it will act as the 'getValue' method of the UDF.
AccumulatorOptimizer - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
A visitor to optimize plans that determines if a reduce plan can run in accumulative mode.
AccumulatorOptimizer(MROperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.AccumulatorOptimizer
 
AccumulatorOptimizer - Class in org.apache.pig.backend.hadoop.executionengine.spark.optimizer
A visitor to optimize plans that determines if a vertex plan can run in accumulative mode.
AccumulatorOptimizer(SparkOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.AccumulatorOptimizer
 
AccumulatorOptimizer - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
A visitor to optimize plans that determines if a vertex plan can run in accumulative mode.
AccumulatorOptimizer(TezOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.AccumulatorOptimizer
 
AccumulatorOptimizerUtil - Class in org.apache.pig.backend.hadoop.executionengine.util
 
AccumulatorOptimizerUtil() - Constructor for class org.apache.pig.backend.hadoop.executionengine.util.AccumulatorOptimizerUtil
 
AccumuloBinaryConverter - Class in org.apache.pig.backend.hadoop.accumulo
A LoadStoreCaster implementation which stores most type implementations as bytes generated from the toString representation with a UTF8 Charset.
AccumuloBinaryConverter() - Constructor for class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
AccumuloStorage - Class in org.apache.pig.backend.hadoop.accumulo
Basic PigStorage implementation that uses Accumulo as the backing store.
AccumuloStorage() - Constructor for class org.apache.pig.backend.hadoop.accumulo.AccumuloStorage
Creates an AccumuloStorage which writes all values in a Tuple with an empty column family and doesn't group column families together on read (creates on Map for all columns)
AccumuloStorage(String) - Constructor for class org.apache.pig.backend.hadoop.accumulo.AccumuloStorage
Create an AccumuloStorage with a CSV of columns-families to use on write and whether columns in a row should be grouped by family on read.
AccumuloStorage(String, String) - Constructor for class org.apache.pig.backend.hadoop.accumulo.AccumuloStorage
 
AccumuloStorageOptions - Class in org.apache.pig.backend.hadoop.accumulo
 
AccumuloStorageOptions() - Constructor for class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
ACOS - Class in org.apache.pig.builtin
ACOS implements a binding to the Java function Math.acos(double) for computing the arc cosine of value of the argument.
ACOS() - Constructor for class org.apache.pig.builtin.ACOS
 
ACOS - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use ACOS
ACOS() - Constructor for class org.apache.pig.piggybank.evaluation.math.ACOS
Deprecated.
 
actionPerformed(ActionEvent) - Method in class org.apache.pig.tools.streams.StreamGenerator
 
Add - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
Add(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
Add(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
add(Number, Number, byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
add(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin.TuplesToSchemaTupleList
 
add(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
add(Tuple) - Method in class org.apache.pig.data.AccumulativeBag
 
add(Tuple) - Method in interface org.apache.pig.data.DataBag
Add a tuple to the bag.
add(Tuple) - Method in class org.apache.pig.data.DefaultAbstractBag
Add a tuple to the bag.
add(Tuple) - Method in class org.apache.pig.data.DistinctDataBag
 
add(Tuple) - Method in class org.apache.pig.data.InternalCachedBag
 
add(Tuple) - Method in class org.apache.pig.data.InternalDistinctBag
 
add(Tuple) - Method in class org.apache.pig.data.InternalSortedBag
 
add(Tuple) - Method in class org.apache.pig.data.LimitedSortedDataBag
Add a tuple to the bag.
add(Tuple) - Method in class org.apache.pig.data.NonSpillableDataBag
 
add(Tuple) - Method in class org.apache.pig.data.ReadOnceBag
 
add(Tuple) - Method in class org.apache.pig.data.SingleTupleBag
 
add(Schema.FieldSchema) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
add(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Insert an operator into the plan.
add(Tuple) - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
add(E) - Method in class org.apache.pig.impl.util.IdentityHashSet
 
add(LoadPushDown.RequiredField) - Method in class org.apache.pig.LoadPushDown.RequiredFieldList
Add a field to the list of required fields.
add(Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
Add a new operator to the plan.
add(Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
Add a new operator to the plan.
add(Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
add(ThreadContext, IRubyObject[]) - Method in class org.apache.pig.scripting.jruby.RubyDataBag
The add method accepts a varargs argument; each argument can be either a random object, a DataBag, or a RubyArray.
add(ThreadContext, IRubyObject[]) - Method in class org.apache.pig.scripting.jruby.RubySchema
This method provides addition semantics, without modifying the original Schema.
add2BagSchema(ResourceSchema.ResourceFieldSchema, ResourceSchema.ResourceFieldSchema) - Static method in class org.apache.pig.piggybank.storage.avro.AvroSchema2Pig
Add a field schema to a bag schema
addAccumulator(PhysicalPlan, List<PhysicalOperator>) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.AccumulatorOptimizerUtil
 
addAlgebraicFuncToCombineFE(POForEach, Map<PhysicalOperator, Integer>) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil
add algebraic functions with appropriate projection to new foreach in combiner
addAlias(String, Schema.FieldSchema) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
addAll(DataBag) - Method in class org.apache.pig.data.AccumulativeBag
 
addAll(DataBag) - Method in interface org.apache.pig.data.DataBag
Add contents of a bag to the bag.
addAll(DataBag) - Method in class org.apache.pig.data.DefaultAbstractBag
 
addAll(Collection<Tuple>) - Method in class org.apache.pig.data.DefaultAbstractBag
 
addAll(Iterable<Tuple>) - Method in class org.apache.pig.data.DefaultAbstractBag
Add contents of an iterable (a collection or a DataBag)
addAll(DataBag) - Method in class org.apache.pig.data.LimitedSortedDataBag
Add contents of a bag to the bag.
addAll(DataBag) - Method in class org.apache.pig.data.NonSpillableDataBag
 
addAll(DataBag) - Method in class org.apache.pig.data.ReadOnceBag
 
addAll(DataBag) - Method in class org.apache.pig.data.SingleTupleBag
 
addAll(DataBag) - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
addAll(Collection<? extends E>) - Method in class org.apache.pig.impl.util.IdentityHashSet
 
addAsLeaf(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Utility method heavily used in the MRCompiler Adds the leaf operator to the plan and connects all existing leaves to the new leaf
addAsRoot(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Adds the root operator to the plan and connects all existing roots the new root
addColsToTuple(DataInput, Tuple) - Method in class org.apache.pig.data.BinInterSedes
 
addColsToTuple(DataInput, Tuple) - Method in interface org.apache.pig.data.InterSedes
The type of next object has been determined to be of type Tuple, add the columns that belong to the tuple to given tuple argument t
addColumn(Mutation, String, String, Value) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorage
Adds the given column family, column qualifier and value to the given mutation
addCombiner(PhysicalPlan, PhysicalPlan, PhysicalPlan, CompilationMessageCollector, boolean) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil
Algebraic functions and distinct in nested plan of a foreach are partially computed in the map and combine phase.
addCounterValue(Result) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
Add current task id and local counter value.
addCrossKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
addCrossKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
addDAGSettingsToConf(Configuration) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState
 
addData(Tuple) - Method in class org.apache.pig.pen.Illustrator
 
addDependencyJars(Configuration, Class<?>...) - Static method in class org.apache.pig.backend.hadoop.accumulo.Utils
 
addDependencyJars(Job, Class<?>...) - Static method in class org.apache.pig.impl.util.JarManager
Add the jars containing the given classes to the job's configuration such that JobClient will ship them to the cluster and add them to the DistributedCache
AddDuration - Class in org.apache.pig.builtin
AddDuration returns the result of a DateTime object plus a Duration object
AddDuration() - Constructor for class org.apache.pig.builtin.AddDuration
 
addEmptyBagOuterJoin(PhysicalPlan, Schema, boolean, String) - Static method in class org.apache.pig.impl.util.CompilerUtils
 
AddExpression - Class in org.apache.pig.newplan.logical.expression
Add Operator
AddExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.AddExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
addExtraResource(URL) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperPlan
 
addExtraResource(String, Path) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperPlan
 
addFailedNativeJobStats(PigStats, NativeSparkOperator, Exception) - Static method in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
addFailJobStats(POStore, SparkOperator, String, JobMetricsListener, JavaSparkContext, Exception) - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
addFailJobStats(String, POStore, SparkOperator, SparkPigStats, Exception) - Static method in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
addField(LogicalSchema.LogicalFieldSchema) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Add a field to this schema.
AddForEach - Class in org.apache.pig.newplan.logical.rules
 
AddForEach(String) - Constructor for class org.apache.pig.newplan.logical.rules.AddForEach
 
AddForEach.AddForEachTransformer - Class in org.apache.pig.newplan.logical.rules
 
addForEachAfter(LogicalPlan, LogicalRelationalOperator, int, Set<Integer>) - Static method in class org.apache.pig.newplan.logical.Util
 
AddForEachTransformer() - Constructor for class org.apache.pig.newplan.logical.rules.AddForEach.AddForEachTransformer
 
addHandleSpec(StreamingCommand.Handle, StreamingCommand.HandleSpec) - Method in class org.apache.pig.impl.streaming.StreamingCommand
addInPlace(ThreadContext, IRubyObject[]) - Method in class org.apache.pig.scripting.jruby.RubySchema
This method provides addition semantics, modifying the original Schema in place.
addInput(OperatorKey) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
addInputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffledValueInputTez
 
addInputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffleTezLoad
 
addInputPlan(PhysicalPlan, boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
addInputs(IdentityHashSet<Tuple>) - Method in class org.apache.pig.pen.Illustrator
 
addInputStatistics() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
addInputStats(POLoad, boolean, boolean) - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
addInputsToSkip(Set<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBloomFilterRearrangeTez
 
addInputsToSkip(Set<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
addInputsToSkip(Set<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POFRJoinTez
 
addInputsToSkip(Set<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POIdentityInOutTez
 
addInputsToSkip(Set<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.PORankTez
 
addInputsToSkip(Set<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffledValueInputTez
 
addInputsToSkip(Set<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffleTezLoad
 
addInputsToSkip(Set<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POSimpleTezLoad
 
addInputsToSkip(Set<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueInputTez
 
addInputsToSkip(Set<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.ReadScalarsTez
 
addInputsToSkip(Set<String>) - Method in interface org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezInput
Add to the list of inputs to skip download if already available in vertex cache
addIsKeyWrappedList(List<Boolean>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
Adds a list of IsKeyWrapped boolean values
addJar(String) - Method in class org.apache.pig.impl.PigContext
 
addJar(URL, String) - Method in class org.apache.pig.impl.PigContext
 
addJobConf(Configuration) - Method in class org.apache.pig.impl.util.UDFContext
Adds the JobConf to this singleton.
addJobConfToEnvironment(Configuration, Map<String, String>) - Static method in class org.apache.pig.impl.streaming.StreamingUtil
 
addJobStats(Job) - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
Add stats for a new Job, which doesn't yet need to be completed.
addJobStats(POStore, SparkOperator, int, JobMetricsListener, JavaSparkContext) - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
addMultiQueryOptimizeConnectionItem(OperatorKey, OperatorKey) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
addNativeJobStats(PigStats, NativeMapReduceOper, boolean) - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
 
addNativeJobStats(PigStats, NativeMapReduceOper, boolean, Exception) - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
 
addNativeJobStats(NativeSparkOperator, String, boolean, Exception) - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
addNativeJobStats(PigStats, NativeSparkOperator) - Static method in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
addNewObjSize(long) - Method in class org.apache.pig.data.SelfSpillBag.MemoryLimits
Submit information about size of another object
addOriginalLocation(String, SourceLocation) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
addOriginalLocation(String, List<PhysicalOperator.OriginalLocation>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
addOutputInfo(POStore, boolean, JobMetricsListener) - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
addOutputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
addOutputStatistics() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
addPackager(Packager) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
Appends the specified package object to the end of the package list.
addPackager(Packager, byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
Appends the specified package object to the end of the package list.
addPathToCache(String) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Add a file to be cached on execute nodes on the cluster.
addPathToShip(String) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Add a file to be shipped to the cluster.
addPathToSkip(String) - Method in class org.apache.pig.impl.PigContext
Add a path to be skipped while automatically shipping binaries for streaming.
addPathToSkip(String) - Method in class org.apache.pig.PigServer
Add a path to be skipped while automatically shipping binaries for streaming.
addPlan(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Appends the specified plan at the end of the list.
addPlan(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
Appends the specified plan to the end of the nested input plan list
addPlan(TezOperPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainer
 
addPlanTransformListener(PlanTransformListener) - Method in class org.apache.pig.newplan.optimizer.PlanOptimizer
Adds a listener to the optimization.
addRank(Result) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
Reads the output tuple from POCounter and the cumulative sum previously calculated.
addRequiredItems(LOLoad, Pair<Map<Integer, Set<String>>, Set<Integer>>) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
addSchema(Schema) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
addScriptFile(String) - Method in class org.apache.pig.impl.PigContext
calls: addScriptFile(path, new File(path)), ensuring that a given path is added to the jar at most once.
addScriptFile(String, String) - Method in class org.apache.pig.impl.PigContext
this method adds script files that must be added to the shipped jar named differently from their local fs path.
addScriptJar(String) - Method in class org.apache.pig.impl.PigContext
 
addSettingsToConf(MapReduceOper, Configuration) - Method in class org.apache.pig.tools.pigstats.mapreduce.MRScriptState
 
addShutdownHookWithPriority(Runnable, int) - Static method in class org.apache.pig.impl.util.Utils
Add shutdown hook that runs before the FileSystem cache shutdown happens.
addSubPlanPropertiesToParent(SparkOperator, SparkOperator) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.MultiQueryOptimizerSpark
 
addTezJobStatsForNative(String, NativeTezOper, boolean) - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
addTezResource(URI) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezResourceManager
 
addTezResource(String, Path) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezResourceManager
 
addTezResources(Set<URI>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezResourceManager
 
addToArray(Object, long, Object) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumReader
Called by the default implementation of GenericDatumReader.readArray(java.lang.Object, org.apache.avro.Schema, org.apache.avro.io.ResolvingDecoder) to add a value.
addToClassPath(String) - Method in class org.apache.pig.impl.util.JavaCompilerHelper
 
addToFilterPlan(LogicalExpression) - Method in class org.apache.pig.newplan.FilterExtractor
 
addToLocalCounter(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
addUnionPredecessor(OperatorKey) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
addVertexGroupStore(OperatorKey, OperatorKey) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
addVertexSettingsToConf(String, TezOperator, Configuration) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState
 
addWorkflowAdjacenciesToConf(MROperPlan, Configuration) - Method in class org.apache.pig.tools.pigstats.mapreduce.MRScriptState
 
addWorkflowAdjacenciesToConf(TezOperPlan, Configuration) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState
 
adjust() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.LimitAdjuster
 
adjustNumReducers(MROperPlan, MapReduceOper, Job) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
Adjust the number of reducers based on the default_parallel, requested parallel and estimated parallel.
aggregateScalarsFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
Algebraic - Interface in org.apache.pig
An interface to declare that an EvalFunc's calculation can be decomposed into intitial, intermediate, and final steps.
AlgebraicBigDecimalMathBase - Class in org.apache.pig.builtin
Core logic for applying an SUM function to a bag of BigDecimals.
AlgebraicBigDecimalMathBase() - Constructor for class org.apache.pig.builtin.AlgebraicBigDecimalMathBase
 
AlgebraicBigDecimalMathBase.Final - Class in org.apache.pig.builtin
 
AlgebraicBigDecimalMathBase.Intermediate - Class in org.apache.pig.builtin
 
AlgebraicBigIntegerMathBase - Class in org.apache.pig.builtin
Core logic for applying an SUM function to a bag of BigIntegers.
AlgebraicBigIntegerMathBase() - Constructor for class org.apache.pig.builtin.AlgebraicBigIntegerMathBase
 
AlgebraicBigIntegerMathBase.Final - Class in org.apache.pig.builtin
 
AlgebraicBigIntegerMathBase.Intermediate - Class in org.apache.pig.builtin
 
AlgebraicByteArrayMathBase - Class in org.apache.pig.builtin
Core logic for applying an accumulative/algebraic math function to a bag of doubles.
AlgebraicByteArrayMathBase() - Constructor for class org.apache.pig.builtin.AlgebraicByteArrayMathBase
 
AlgebraicByteArrayMathBase.Final - Class in org.apache.pig.builtin
 
AlgebraicByteArrayMathBase.Initial - Class in org.apache.pig.builtin
 
AlgebraicByteArrayMathBase.Intermediate - Class in org.apache.pig.builtin
 
AlgebraicDoubleMathBase - Class in org.apache.pig.builtin
Core logic for applying an accumulative/algebraic math function to a bag of doubles.
AlgebraicDoubleMathBase() - Constructor for class org.apache.pig.builtin.AlgebraicDoubleMathBase
 
AlgebraicDoubleMathBase.Final - Class in org.apache.pig.builtin
 
AlgebraicDoubleMathBase.Intermediate - Class in org.apache.pig.builtin
 
AlgebraicEvalFunc<T> - Class in org.apache.pig
This class is used to provide a free implementation of the Accumulator interface and EvalFunc class in the case of an Algebraic function.
AlgebraicEvalFunc(String...) - Constructor for class org.apache.pig.AlgebraicEvalFunc
It is key that if a subclass has a constructor, that it calls super(args...) or else this class will not instantiate properly.
AlgebraicFinal - Annotation Type in org.apache.pig.scripting.groovy
This annotation is to be used on a Groovy method which is part of an Algebraic UDF to indicate that it will act as the exec method of the 'Final' class of the UDF.
AlgebraicFloatMathBase - Class in org.apache.pig.builtin
Core logic for applying an accumulative/algebraic math function to a bag of Floats.
AlgebraicFloatMathBase() - Constructor for class org.apache.pig.builtin.AlgebraicFloatMathBase
 
AlgebraicFloatMathBase.Final - Class in org.apache.pig.builtin
 
AlgebraicFloatMathBase.Intermediate - Class in org.apache.pig.builtin
 
AlgebraicFunctionWrapper() - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
AlgebraicFunctionWrapper(String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
AlgebraicFunctionWrapper() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
AlgebraicFunctionWrapper(String, String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper
In addition to registering the fileName and the functionName (which are given based on the arguments passed to super() in the containing class's constructor, each extending class will register their "stage," which will serve as the method to invoke on the Ruby class.
AlgebraicInitial - Annotation Type in org.apache.pig.scripting.groovy
This annotation is to be used on a Groovy method which is part of an Algebraic UDF to indicate that it will act as the exec method of the 'Initial' class of the UDF.
AlgebraicIntermed - Annotation Type in org.apache.pig.scripting.groovy
This annotation is to be used on a Groovy method which is part of an Algebraic UDF to indicate that it will act as the exec method of the 'Intermed' class of the UDF.
AlgebraicIntMathBase - Class in org.apache.pig.builtin
Core logic for applying an accumulative/algebraic math function to a bag of doubles.
AlgebraicIntMathBase() - Constructor for class org.apache.pig.builtin.AlgebraicIntMathBase
 
AlgebraicIntMathBase.Final - Class in org.apache.pig.builtin
 
AlgebraicIntMathBase.Intermediate - Class in org.apache.pig.builtin
 
AlgebraicLongMathBase - Class in org.apache.pig.builtin
Core logic for applying an accumulative/algebraic math function to a bag of Longs.
AlgebraicLongMathBase() - Constructor for class org.apache.pig.builtin.AlgebraicLongMathBase
 
AlgebraicLongMathBase.Final - Class in org.apache.pig.builtin
 
AlgebraicLongMathBase.Intermediate - Class in org.apache.pig.builtin
 
alias - Variable in class org.apache.pig.backend.hadoop.executionengine.HJob
 
alias - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
alias - Variable in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Alias for this field.
alias - Variable in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
alias - Variable in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
ALIAS - Static variable in class org.apache.pig.tools.pigstats.JobStats
 
ALIAS_LOCATION - Static variable in class org.apache.pig.tools.pigstats.JobStats
 
aliasOuputMap - Variable in class org.apache.pig.tools.pigstats.PigStats
 
AliasVisitor(PhysicalPlan, List<String>, List<String>) - Constructor for class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
AllExpressionVisitor - Class in org.apache.pig.newplan.logical.optimizer
A visitor that walks a logical plan and then applies a given LogicalExpressionVisitor to all expressions it encounters.
AllExpressionVisitor(OperatorPlan, PlanWalker) - Constructor for class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
allInputFromPredecessorConsumed - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
AllLoader - Class in org.apache.pig.piggybank.storage
The AllLoader provides the ability to point pig at a folder that contains files in multiple formats e.g.
AllLoader() - Constructor for class org.apache.pig.piggybank.storage.AllLoader
 
AllLoader(String) - Constructor for class org.apache.pig.piggybank.storage.AllLoader
 
AllLoader.AllLoaderInputFormat - Class in org.apache.pig.piggybank.storage
InputFormat that encapsulates the correct input format based on the file type.
AllLoader.AllReader - Class in org.apache.pig.piggybank.storage
This is where the logic is for selecting the correct Loader.
AllLoaderInputFormat(String) - Constructor for class org.apache.pig.piggybank.storage.AllLoader.AllLoaderInputFormat
 
allOutputFromBinaryProcessed - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ABS
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.AddDuration
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ARITY
Deprecated.
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.Assert
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.BagSize
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.BagToString
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.BagToTuple
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.Base
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.BigDecimalAbs
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.BigIntegerAbs
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.CONCAT
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ConstantSize
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.CubeDimensions
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.CurrentTime
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.DaysBetween
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.DIFF
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.DoubleRound
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.DoubleRoundTo
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ENDSWITH
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.EqualsIgnoreCase
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.FloatAbs
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.FloatRound
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.FloatRoundTo
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.GetDay
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.GetHour
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.GetMilliSecond
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.GetMinute
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.GetMonth
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.GetSecond
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.GetWeek
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.GetWeekYear
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.GetYear
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.HoursBetween
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.INDEXOF
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.IntAbs
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.INVERSEMAP
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.IsEmpty
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.KEYSET
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.LAST_INDEX_OF
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.LCFIRST
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.LongAbs
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.LOWER
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.LTRIM
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.MapSize
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.MilliSecondsBetween
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.MinutesBetween
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.MonthsBetween
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.PluckTuple
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.REGEX_EXTRACT
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.REGEX_EXTRACT_ALL
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.REGEX_SEARCH
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.REPLACE
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.RollupDimensions
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ROUND
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ROUND_TO
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.RTRIM
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.SecondsBetween
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.SIZE
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.SPRINTF
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.STARTSWITH
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.StringConcat
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.StringSize
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.STRSPLIT
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.STRSPLITTOBAG
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.SUBSTRING
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.SUBTRACT
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.SubtractDuration
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.TOBAG
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ToDate
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ToDate2ARGS
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ToDate3ARGS
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ToDateISO
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.TOKENIZE
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.TOMAP
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ToMilliSeconds
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ToString
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.TOTUPLE
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.ToUnixTime
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.TRIM
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.TupleSize
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.UCFIRST
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.UPPER
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.VALUELIST
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.VALUESET
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.WeeksBetween
 
allowCompileTimeCalculation() - Method in class org.apache.pig.builtin.YearsBetween
 
allowCompileTimeCalculation() - Method in class org.apache.pig.EvalFunc
Whether the UDF should be evaluated at compile time if all inputs are constant.
allowRecursive - Variable in class org.apache.pig.builtin.AvroStorage
 
AllReader(String) - Constructor for class org.apache.pig.piggybank.storage.AllLoader.AllReader
 
AllSameExpressionVisitor - Class in org.apache.pig.newplan.logical.expression
 
AllSameExpressionVisitor(OperatorPlan, PlanWalker) - Constructor for class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
AllSameRalationalNodesVisitor - Class in org.apache.pig.newplan.logical.optimizer
A visitor that walks the logical plan and calls the same method on every type of node.
AllSameRalationalNodesVisitor(OperatorPlan, PlanWalker) - Constructor for class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
alreadyClosed - Variable in class org.apache.pig.impl.streaming.InputHandler
 
alreadyClosed - Variable in class org.apache.pig.impl.streaming.OutputHandler
 
AmendableTuple - Class in org.apache.pig.data
 
AmendableTuple(int, Object) - Constructor for class org.apache.pig.data.AmendableTuple
 
AndExpression - Class in org.apache.pig.newplan.logical.expression
Boolean and expression.
AndExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.AndExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
annotate(String, Object) - Method in class org.apache.pig.newplan.Operator
Add an annotation to a node in the plan.
annotations - Variable in class org.apache.pig.newplan.Operator
 
append(Object) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
append(DataByteArray) - Method in class org.apache.pig.data.DataByteArray
Append given byte array to the internal byte array.
append(byte[]) - Method in class org.apache.pig.data.DataByteArray
 
append(byte[], int, int) - Method in class org.apache.pig.data.DataByteArray
 
append(String) - Method in class org.apache.pig.data.DataByteArray
 
append(Object) - Method in class org.apache.pig.data.DefaultTuple
Append a field to a tuple.
append(Object) - Method in class org.apache.pig.data.SchemaTuple
 
append(Object) - Method in class org.apache.pig.data.TargetedTuple
 
append(Object) - Method in interface org.apache.pig.data.Tuple
Append a field to a tuple.
append(Object) - Method in class org.apache.pig.data.UnlimitedNullTuple
 
append(Object) - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
append(Object) - Method in class org.apache.pig.pen.util.ExampleTuple
 
append(ThreadContext, IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubyDataByteArray
This calls to the append function of the underlying DataByteArray.
AppendableSchemaTuple<T extends AppendableSchemaTuple<T>> - Class in org.apache.pig.data
 
AppendableSchemaTuple() - Constructor for class org.apache.pig.data.AppendableSchemaTuple
 
appendedFieldsSize() - Method in class org.apache.pig.data.AppendableSchemaTuple
 
apply(S) - Method in interface org.apache.pig.ExceptionalFunction
Performs a unit of work on item, possibly throwing E in the process.
apply(S) - Method in interface org.apache.pig.Function
 
applySecondaryKeySort(PhysicalPlan, PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil
 
ARITY - Class in org.apache.pig.builtin
Deprecated.
Use SIZE instead.
ARITY() - Constructor for class org.apache.pig.builtin.ARITY
Deprecated.
 
ARRAY_FIELD - Static variable in class org.apache.pig.piggybank.storage.avro.AvroSchema2Pig
 
asCollection(String) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
asCollection(String) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
asContainer(String) - Method in interface org.apache.pig.backend.datastorage.DataStorage
Created an entity handle for a container.
asContainer(ContainerDescriptor) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
asContainer(String, String) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
asContainer(ContainerDescriptor, String) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
asContainer(ContainerDescriptor, ContainerDescriptor) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
asContainer(String) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
asContainer(ContainerDescriptor) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
asContainer(String, String) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
asContainer(ContainerDescriptor, String) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
asContainer(ContainerDescriptor, ContainerDescriptor) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
asElement(String) - Method in interface org.apache.pig.backend.datastorage.DataStorage
Creates an entity handle for an object (no containment relation) from a String
asElement(ElementDescriptor) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
asElement(String, String) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
asElement(ContainerDescriptor, String) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
asElement(ContainerDescriptor, ElementDescriptor) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
asElement(String) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
asElement(ElementDescriptor) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
asElement(String, String) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
asElement(ContainerDescriptor, String) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
asElement(ContainerDescriptor, ElementDescriptor) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
ASIN - Class in org.apache.pig.builtin
ASIN implements a binding to the Java function Math.asin(double) for computing the arc sine of value of the argument.
ASIN() - Constructor for class org.apache.pig.builtin.ASIN
 
ASIN - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use ASIN
ASIN() - Constructor for class org.apache.pig.piggybank.evaluation.math.ASIN
Deprecated.
 
Assert - Class in org.apache.pig.builtin
 
Assert() - Constructor for class org.apache.pig.builtin.Assert
 
assertPredecessorSize(List<<any>>, PhysicalOperator, int) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkUtil
 
assertPredecessorSizeGreaterThan(List<<any>>, PhysicalOperator, int) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkUtil
 
ASTERISK - Static variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
ATAN - Class in org.apache.pig.builtin
ATAN implements a binding to the Java function Math.atan(double) for computing the arc tangent of value of the argument.
ATAN() - Constructor for class org.apache.pig.builtin.ATAN
 
ATAN - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use ATAN
ATAN() - Constructor for class org.apache.pig.piggybank.evaluation.math.ATAN
Deprecated.
 
ATAN2 - Class in org.apache.pig.piggybank.evaluation.math
math.ATAN2 implements a binding to the Java function Math.atan2(double,double).
ATAN2() - Constructor for class org.apache.pig.piggybank.evaluation.math.ATAN2
 
ATSEvent(String, String) - Constructor for class org.apache.pig.backend.hadoop.PigATSClient.ATSEvent
 
attachInput(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
attachInput(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
Overridden since the attachment of the new input should cause the old processing to end.
attachInput(Tuple, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
attachInput(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
Shorts the input path of this operator by providing the input tuple directly
attachInput(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
attachInput(Object, DataBag[], boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.CombinerPackager
 
attachInput(Object, DataBag[], boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.JoinPackager
 
attachInput(Object, DataBag[], boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.LitePackager
 
attachInput(Object, DataBag[], boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
attachInput(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
Overridden since the attachment of the new input should cause the old processing to end.
attachInput(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
Overridden since the attachment of the new input should cause the old processing to end.
attachInput(PigNullableWritable, Iterator<NullableTuple>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
Attaches the required inputs
attachInput(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
Overridden since the attachment of the new input should cause the old processing to end.
attachInput(Object, DataBag[], boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.BloomPackager
 
attachInputs(Map<String, List<Tuple>>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoinSpark
 
attachInputs(Map<String, LogicalInput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBloomFilterRearrangeTez
 
attachInputs(Map<String, LogicalInput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
attachInputs(Map<String, LogicalInput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POFRJoinTez
 
attachInputs(Map<String, LogicalInput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POIdentityInOutTez
 
attachInputs(Map<String, LogicalInput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.PORankTez
 
attachInputs(Map<String, LogicalInput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffledValueInputTez
 
attachInputs(Map<String, LogicalInput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffleTezLoad
 
attachInputs(Map<String, LogicalInput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POSimpleTezLoad
 
attachInputs(Map<String, LogicalInput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueInputTez
 
attachInputs(Map<String, LogicalInput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.ReadScalarsTez
 
attachInputs(Map<String, LogicalInput>, Configuration) - Method in interface org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezInput
Attach the inputs to the operator.
attachInputToPlans(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
attachOutputs(Map<String, LogicalOutput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
attachOutputs(Map<String, LogicalOutput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
attachOutputs(Map<String, LogicalOutput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterTez
 
attachOutputs(Map<String, LogicalOutput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POIdentityInOutTez
 
attachOutputs(Map<String, LogicalOutput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
attachOutputs(Map<String, LogicalOutput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POStoreTez
 
attachOutputs(Map<String, LogicalOutput>, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
attachOutputs(Map<String, LogicalOutput>, Configuration) - Method in interface org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezOutput
 
attachStorePlan(String, LogicalPlan, String, String, Operator, String, PigContext) - Static method in class org.apache.pig.parser.QueryParserUtils
 
AUDIT_ID_MAX_LENGTH - Static variable in class org.apache.pig.backend.hadoop.PigATSClient
 
AugmentBaseDataVisitor - Class in org.apache.pig.pen
 
AugmentBaseDataVisitor(OperatorPlan, Map<Operator, PhysicalOperator>, Map<LOLoad, DataBag>, Map<Operator, DataBag>) - Constructor for class org.apache.pig.pen.AugmentBaseDataVisitor
 
authorizations - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
AUTHORIZATIONS_OPTION - Static variable in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
available() - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
available() - Method in class org.apache.pig.impl.io.FileLocalizer.DataStorageInputStreamIterator
 
AVG - Class in org.apache.pig.builtin
Generates the average of a set of values.
AVG() - Constructor for class org.apache.pig.builtin.AVG
 
AVG.Final - Class in org.apache.pig.builtin
 
AVG.Initial - Class in org.apache.pig.builtin
 
AVG.Intermediate - Class in org.apache.pig.builtin
 
avgTupleMemSz - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
avoidContainerReuseIfInputSplitInDisk() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezDagBuilder
 
AvroArrayReader - Class in org.apache.pig.impl.util.avro
RecordReader for Avro files
AvroArrayReader(Schema) - Constructor for class org.apache.pig.impl.util.avro.AvroArrayReader
Creates new instance of AvroRecordReader.
AvroBagWrapper<T> - Class in org.apache.pig.impl.util.avro
Class that implements the Pig bag interface, wrapping an Avro array.
AvroBagWrapper(GenericArray<T>) - Constructor for class org.apache.pig.impl.util.avro.AvroBagWrapper
Create new AvroBagWrapper instance.
AvroMapWrapper - Class in org.apache.pig.impl.util.avro
Wrapper for map objects, so we can translate UTF8 objects to Strings if we encounter them.
AvroMapWrapper(Map<CharSequence, Object>) - Constructor for class org.apache.pig.impl.util.avro.AvroMapWrapper
Creates a new AvroMapWrapper object from the map object .
AvroRecordReader - Class in org.apache.pig.impl.util.avro
RecordReader for Avro files
AvroRecordReader(Schema) - Constructor for class org.apache.pig.impl.util.avro.AvroRecordReader
Creates new instance of AvroRecordReader.
AvroRecordWriter - Class in org.apache.pig.impl.util.avro
RecordWriter for Avro objects.
AvroRecordWriter(Path, Configuration) - Constructor for class org.apache.pig.impl.util.avro.AvroRecordWriter
Creates new AvroRecordWriter.
AvroSchema2Pig - Class in org.apache.pig.piggybank.storage.avro
This class converts Avro schema to Pig schema
AvroSchema2Pig() - Constructor for class org.apache.pig.piggybank.storage.avro.AvroSchema2Pig
 
AvroSchemaManager - Class in org.apache.pig.piggybank.storage.avro
This class creates two maps out of a given Avro schema.
AvroSchemaManager(Schema) - Constructor for class org.apache.pig.piggybank.storage.avro.AvroSchemaManager
Construct with a given schema
avroSchemaToResourceSchema(Schema, Boolean) - Static method in class org.apache.pig.impl.util.avro.AvroStorageSchemaConversionUtilities
Translates an Avro schema to a Resource Schema (for Pig).
AvroStorage - Class in org.apache.pig.builtin
Pig UDF for reading and writing Avro data.
AvroStorage() - Constructor for class org.apache.pig.builtin.AvroStorage
Creates new instance of Pig Storage function, without specifying the schema.
AvroStorage(String) - Constructor for class org.apache.pig.builtin.AvroStorage
Creates new instance of Pig Storage function.
AvroStorage(String, String) - Constructor for class org.apache.pig.builtin.AvroStorage
Creates new instance of AvroStorage function, specifying output schema properties.
AvroStorage - Class in org.apache.pig.piggybank.storage.avro
AvroStorage is used to load/store Avro data
Document can be found here
AvroStorage() - Constructor for class org.apache.pig.piggybank.storage.avro.AvroStorage
Empty constructor.
AvroStorage(String[]) - Constructor for class org.apache.pig.piggybank.storage.avro.AvroStorage
Constructor of quoted string list
AvroStorageDataConversionUtilities - Class in org.apache.pig.impl.util.avro
Utility classes for AvroStorage; contains static methods for converting between Avro and Pig objects.
AvroStorageDataConversionUtilities() - Constructor for class org.apache.pig.impl.util.avro.AvroStorageDataConversionUtilities
 
AvroStorageInputStream - Class in org.apache.pig.piggybank.storage.avro
Adapt an FSDataInputStream to SeekableInput.
AvroStorageInputStream(Path, TaskAttemptContext) - Constructor for class org.apache.pig.piggybank.storage.avro.AvroStorageInputStream
Construct given a path and a configuration.
AvroStorageLog - Class in org.apache.pig.piggybank.storage.avro
Simple logging utils of this package
AvroStorageLog() - Constructor for class org.apache.pig.piggybank.storage.avro.AvroStorageLog
 
AvroStorageSchemaConversionUtilities - Class in org.apache.pig.impl.util.avro
Static methods for converting from Avro Schema object to Pig Schema objects, and vice versa.
AvroStorageSchemaConversionUtilities() - Constructor for class org.apache.pig.impl.util.avro.AvroStorageSchemaConversionUtilities
 
AvroStorageUtils - Class in org.apache.pig.piggybank.storage.avro
This is utility class for this package
AvroStorageUtils() - Constructor for class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
 
AvroTupleWrapper<T extends org.apache.avro.generic.IndexedRecord> - Class in org.apache.pig.impl.util.avro
Object that wraps an Avro object in a tuple.
AvroTupleWrapper(T) - Constructor for class org.apache.pig.impl.util.avro.AvroTupleWrapper
Creates a new AvroTupleWrapper object.

B

BackendException - Exception in org.apache.pig.backend
 
BackendException() - Constructor for exception org.apache.pig.backend.BackendException
Create a new BackendException with null as the error message.
BackendException(String) - Constructor for exception org.apache.pig.backend.BackendException
Create a new BackendException with the specified message and cause.
BackendException(Throwable) - Constructor for exception org.apache.pig.backend.BackendException
Create a new BackendException with the specified cause.
BackendException(String, Throwable) - Constructor for exception org.apache.pig.backend.BackendException
Create a new BackendException with the specified message and cause.
BackendException(String, int) - Constructor for exception org.apache.pig.backend.BackendException
Create a new BackendException with the specified message and cause.
BackendException(String, int, Throwable) - Constructor for exception org.apache.pig.backend.BackendException
Create a new BackendException with the specified message and cause.
BackendException(String, int, byte) - Constructor for exception org.apache.pig.backend.BackendException
Create a new BackendException with the specified message and cause.
BackendException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.backend.BackendException
Create a new BackendException with the specified message and cause.
BackendException(String, int, boolean) - Constructor for exception org.apache.pig.backend.BackendException
Create a new BackendException with the specified message and cause.
BackendException(String, int, byte, boolean) - Constructor for exception org.apache.pig.backend.BackendException
Create a new BackendException with the specified message and cause.
BackendException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.backend.BackendException
Create a new BackendException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
BackendException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.backend.BackendException
Create a new BackendException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
backendException - Variable in class org.apache.pig.backend.hadoop.executionengine.HJob
 
bag(Tuple...) - Static method in class org.apache.pig.builtin.mock.Storage
 
BAG - Static variable in class org.apache.pig.data.BinInterSedes
 
BAG - Static variable in class org.apache.pig.data.DataType
 
bag(ThreadContext, IRubyObject, IRubyObject, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a ruby method which takes a name and an array of arguments and constructs a Bag schema from them.
bag(ThreadContext, IRubyObject, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a ruby method which takes an array of arguments and constructs a Bag schema from them.
bagDataTypeInCombinePlan(PhysicalPlan) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
BagDelimiterTuple() - Constructor for class org.apache.pig.data.DefaultAbstractBag.BagDelimiterTuple
 
BagFactory - Class in org.apache.pig.data
Factory for constructing different types of bags.
BagFactory() - Constructor for class org.apache.pig.data.BagFactory
Construct a new BagFactory
BagFormat - Class in org.apache.pig.impl.util
 
BagFormat() - Constructor for class org.apache.pig.impl.util.BagFormat
 
BagJrubyAlgebraicEvalFunc(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.BagJrubyAlgebraicEvalFunc
 
bags - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
bags - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
BagSize - Class in org.apache.pig.builtin
This method should never be used directly, use SIZE.
BagSize() - Constructor for class org.apache.pig.builtin.BagSize
 
BagToString - Class in org.apache.pig.builtin
Flatten a bag into a string.
BagToString() - Constructor for class org.apache.pig.builtin.BagToString
 
BagToTuple - Class in org.apache.pig.builtin
Flatten a bag into a tuple.
BagToTuple() - Constructor for class org.apache.pig.builtin.BagToTuple
 
Base - Class in org.apache.pig.builtin
base class for math udfs
Base() - Constructor for class org.apache.pig.builtin.Base
 
Base - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use Base
Base() - Constructor for class org.apache.pig.piggybank.evaluation.math.Base
Deprecated.
 
BaseOperatorPlan - Class in org.apache.pig.newplan
 
BaseOperatorPlan() - Constructor for class org.apache.pig.newplan.BaseOperatorPlan
 
BaseOperatorPlan(BaseOperatorPlan) - Constructor for class org.apache.pig.newplan.BaseOperatorPlan
 
BetweenExpression(Object, Object) - Constructor for class org.apache.pig.Expression.BetweenExpression
 
BIG_JOB_LOG_MSG - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
BIGCHARARRAY - Static variable in class org.apache.pig.data.DataType
Internal use only.
BIGDECIMAL - Static variable in class org.apache.pig.data.BinInterSedes
 
BIGDECIMAL - Static variable in class org.apache.pig.data.DataType
 
BIGDECIMAL_MINIMAL_SCALE - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
BigDecimalAbs - Class in org.apache.pig.builtin
 
BigDecimalAbs() - Constructor for class org.apache.pig.builtin.BigDecimalAbs
 
BigDecimalAvg - Class in org.apache.pig.builtin
This method should never be used directly, use AVG.
BigDecimalAvg() - Constructor for class org.apache.pig.builtin.BigDecimalAvg
 
BigDecimalAvg.Final - Class in org.apache.pig.builtin
 
BigDecimalAvg.Initial - Class in org.apache.pig.builtin
 
BigDecimalAvg.Intermediate - Class in org.apache.pig.builtin
 
BigDecimalGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.BigDecimalGroovyAlgebraicEvalFunc
 
BigDecimalMax - Class in org.apache.pig.builtin
This method should never be used directly, use MAX.
BigDecimalMax() - Constructor for class org.apache.pig.builtin.BigDecimalMax
 
BigDecimalMax.Final - Class in org.apache.pig.builtin
 
BigDecimalMax.Intermediate - Class in org.apache.pig.builtin
 
BigDecimalMin - Class in org.apache.pig.builtin
This method should never be used directly, use MIN.
BigDecimalMin() - Constructor for class org.apache.pig.builtin.BigDecimalMin
 
BigDecimalMin.Final - Class in org.apache.pig.builtin
 
BigDecimalMin.Intermediate - Class in org.apache.pig.builtin
 
BigDecimalSum - Class in org.apache.pig.builtin
This method should never be used directly, use SUM.
BigDecimalSum() - Constructor for class org.apache.pig.builtin.BigDecimalSum
 
BigDecimalSum.Final - Class in org.apache.pig.builtin
 
BigDecimalSum.Intermediate - Class in org.apache.pig.builtin
 
BigDecimalWrapper - Class in org.apache.pig.builtin
Max and min seeds cannot be defined to BigDecimal as the value could go as large as The computer allows.
BigDecimalWrapper(BigInteger) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(BigInteger, int) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(BigInteger, int, MathContext) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(BigInteger, MathContext) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(char[]) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(char[], int, int) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(char[], int, int, MathContext) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(char[], MathContext) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(double) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(double, MathContext) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(int) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(int, MathContext) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(long) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(long, MathContext) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(String) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWrapper(String, MathContext) - Constructor for class org.apache.pig.builtin.BigDecimalWrapper
 
BigDecimalWritable - Class in org.apache.pig.backend.hadoop
 
BigDecimalWritable() - Constructor for class org.apache.pig.backend.hadoop.BigDecimalWritable
 
BigDecimalWritable(BigDecimal) - Constructor for class org.apache.pig.backend.hadoop.BigDecimalWritable
 
BigDecimalWritable.Comparator - Class in org.apache.pig.backend.hadoop
A Comparator optimized for BigDecimalWritable.
BIGINTEGER - Static variable in class org.apache.pig.data.BinInterSedes
 
BIGINTEGER - Static variable in class org.apache.pig.data.DataType
 
BigIntegerAbs - Class in org.apache.pig.builtin
 
BigIntegerAbs() - Constructor for class org.apache.pig.builtin.BigIntegerAbs
 
BigIntegerAvg - Class in org.apache.pig.builtin
This method should never be used directly, use AVG.
BigIntegerAvg() - Constructor for class org.apache.pig.builtin.BigIntegerAvg
 
BigIntegerAvg.Final - Class in org.apache.pig.builtin
 
BigIntegerAvg.Initial - Class in org.apache.pig.builtin
 
BigIntegerAvg.Intermediate - Class in org.apache.pig.builtin
 
BigIntegerGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.BigIntegerGroovyAlgebraicEvalFunc
 
BigIntegerMax - Class in org.apache.pig.builtin
This method should never be used directly, use MAX.
BigIntegerMax() - Constructor for class org.apache.pig.builtin.BigIntegerMax
 
BigIntegerMax.Final - Class in org.apache.pig.builtin
 
BigIntegerMax.Intermediate - Class in org.apache.pig.builtin
 
BigIntegerMin - Class in org.apache.pig.builtin
This method should never be used directly, use MIN.
BigIntegerMin() - Constructor for class org.apache.pig.builtin.BigIntegerMin
 
BigIntegerMin.Final - Class in org.apache.pig.builtin
 
BigIntegerMin.Intermediate - Class in org.apache.pig.builtin
 
BigIntegerSum - Class in org.apache.pig.builtin
This method should never be used directly, use SUM.
BigIntegerSum() - Constructor for class org.apache.pig.builtin.BigIntegerSum
 
BigIntegerSum.Final - Class in org.apache.pig.builtin
 
BigIntegerSum.Intermediate - Class in org.apache.pig.builtin
 
BigIntegerWrapper - Class in org.apache.pig.builtin
Max and min seeds cannot be defined to BigInteger as the value could go as large as The computer allows.
BigIntegerWrapper(byte[]) - Constructor for class org.apache.pig.builtin.BigIntegerWrapper
 
BigIntegerWrapper(int, byte[]) - Constructor for class org.apache.pig.builtin.BigIntegerWrapper
 
BigIntegerWrapper(int, int, Random) - Constructor for class org.apache.pig.builtin.BigIntegerWrapper
 
BigIntegerWrapper(int, Random) - Constructor for class org.apache.pig.builtin.BigIntegerWrapper
 
BigIntegerWrapper(String) - Constructor for class org.apache.pig.builtin.BigIntegerWrapper
 
BigIntegerWrapper(String, int) - Constructor for class org.apache.pig.builtin.BigIntegerWrapper
 
BigIntegerWritable - Class in org.apache.pig.backend.hadoop
 
BigIntegerWritable() - Constructor for class org.apache.pig.backend.hadoop.BigIntegerWritable
 
BigIntegerWritable(BigInteger) - Constructor for class org.apache.pig.backend.hadoop.BigIntegerWritable
 
BigIntegerWritable.Comparator - Class in org.apache.pig.backend.hadoop
A Comparator optimized for BigIntegerWritable.
Bin - Class in org.apache.pig.piggybank.evaluation.decode
Syntax: String Bin(arithmetic_expression, string1, ,..., stringN, sentinelN, default_string). Logic: if (arithmetic_expression<=sentinel1) return string1;
......
Bin() - Constructor for class org.apache.pig.piggybank.evaluation.decode.Bin
 
BinaryComparisonOperator - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
This is a base class for all binary comparison operators.
BinaryComparisonOperator(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryComparisonOperator
 
BinaryComparisonOperator(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryComparisonOperator
 
BinaryExpression(Expression, Expression, Expression.OpType) - Constructor for class org.apache.pig.Expression.BinaryExpression
 
BinaryExpression - Class in org.apache.pig.newplan.logical.expression
Superclass for all binary expressions
BinaryExpression(String, OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.BinaryExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
BinaryExpressionOperator - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
A base class for all Binary expression operators.
BinaryExpressionOperator(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
BinaryExpressionOperator(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
binaryInputQueue - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
binaryOutputQueue - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
BinCond - Class in org.apache.pig.piggybank.evaluation.decode
Syntax: String BinCond(boolean_expression1, mapping_string1, ..., boolean_expressionN, mapping_stringN, other_string). Logic: if (boolean_expression1) return mapping_string1;
......
BinCond() - Constructor for class org.apache.pig.piggybank.evaluation.decode.BinCond
 
BinCondExpression - Class in org.apache.pig.newplan.logical.expression
 
BinCondExpression(OperatorPlan, LogicalExpression, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.BinCondExpression
Will add this operator to the plan and connect it to the left and right hand side operators and the condition operator
bind(Object) - Method in class org.apache.pig.scripting.js.JSPig
javascript helper for binding parameters.
bind() - Method in class org.apache.pig.scripting.js.JSPig
bind(Map<String, Object>) - Method in class org.apache.pig.scripting.Pig
Bind this to a set of variables.
bind(List<Map<String, Object>>) - Method in class org.apache.pig.scripting.Pig
Bind this to multiple sets of variables.
bind() - Method in class org.apache.pig.scripting.Pig
Bind a Pig object to variables in the host language (optional operation).
bindTo(OutputStream) - Method in class org.apache.pig.impl.streaming.FileInputHandler
 
bindTo(String, BufferedPositionedInputStream, long, long) - Method in class org.apache.pig.impl.streaming.FileOutputHandler
 
bindTo(OutputStream) - Method in class org.apache.pig.impl.streaming.InputHandler
Bind the InputHandler to the OutputStream from which it reads input and sends it to the managed process.
bindTo(String, BufferedPositionedInputStream, long, long) - Method in class org.apache.pig.impl.streaming.OutputHandler
Bind the OutputHandler to the InputStream from which to read the output data of the managed process.
BinInterSedes - Class in org.apache.pig.data
A class to handle reading and writing of intermediate results of data types.
BinInterSedes() - Constructor for class org.apache.pig.data.BinInterSedes
 
BinInterSedes.BinInterSedesTupleRawComparator - Class in org.apache.pig.data
 
BinInterSedesTupleRawComparator() - Constructor for class org.apache.pig.data.BinInterSedes.BinInterSedesTupleRawComparator
 
BinSedesTuple - Class in org.apache.pig.data
This tuple has a faster (de)serialization mechanism.
BinSedesTupleFactory - Class in org.apache.pig.data
Default implementation of TupleFactory.
BinSedesTupleFactory() - Constructor for class org.apache.pig.data.BinSedesTupleFactory
 
BinStorage - Class in org.apache.pig.builtin
Load and store data in a binary format.
BinStorage() - Constructor for class org.apache.pig.builtin.BinStorage
 
BinStorage(String) - Constructor for class org.apache.pig.builtin.BinStorage
 
BinStorageInputFormat - Class in org.apache.pig.impl.io
 
BinStorageInputFormat() - Constructor for class org.apache.pig.impl.io.BinStorageInputFormat
 
BinStorageOutputFormat - Class in org.apache.pig.impl.io
 
BinStorageOutputFormat() - Constructor for class org.apache.pig.impl.io.BinStorageOutputFormat
 
BinStorageRecordReader - Class in org.apache.pig.impl.io
Treats keys as offset in file and value as line.
BinStorageRecordReader() - Constructor for class org.apache.pig.impl.io.BinStorageRecordReader
 
BinStorageRecordWriter - Class in org.apache.pig.impl.io
 
BinStorageRecordWriter(DataOutputStream) - Constructor for class org.apache.pig.impl.io.BinStorageRecordWriter
 
bitSetToLong(BitSet) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
BlackAndWhitelistFilter - Class in org.apache.pig.validator
This Filter handles black and whitelisting of Pig commands.
BlackAndWhitelistFilter(PigServer) - Constructor for class org.apache.pig.validator.BlackAndWhitelistFilter
 
BlackAndWhitelistFilter(PigContext) - Constructor for class org.apache.pig.validator.BlackAndWhitelistFilter
 
BlackAndWhitelistValidator - Class in org.apache.pig.validator
This validator walks through the list of operators defined in PigConfiguration.PIG_BLACKLIST and PigConfiguration.PIG_WHITELIST and checks whether the operation is permitted.
BlackAndWhitelistValidator(PigContext, OperatorPlan) - Constructor for class org.apache.pig.validator.BlackAndWhitelistValidator
 
BLOCK_REPLICATION_KEY - Static variable in interface org.apache.pig.backend.datastorage.ElementDescriptor
Available from getConfiguration as a String and getStatistics as a Short.
BLOCK_SIZE_KEY - Static variable in interface org.apache.pig.backend.datastorage.ElementDescriptor
Available from getConfiguration as a String and getStatistics as a Long.
Bloom - Class in org.apache.pig.builtin
Use a Bloom filter build previously by BuildBloom.
Bloom() - Constructor for class org.apache.pig.builtin.Bloom
 
Bloom(String) - Constructor for class org.apache.pig.builtin.Bloom
The filename containing the serialized Bloom filter.
bloomIn(DataByteArray) - Static method in class org.apache.pig.builtin.BuildBloomBase
 
bloomOr(Tuple) - Method in class org.apache.pig.builtin.BuildBloomBase
 
bloomOut() - Method in class org.apache.pig.builtin.BuildBloomBase
 
BloomPackager - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
 
BloomPackager(boolean, int, int, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.BloomPackager
 
BOOLEAN - Static variable in class org.apache.pig.data.DataType
 
BOOLEAN_FALSE - Static variable in class org.apache.pig.data.BinInterSedes
 
BOOLEAN_TRUE - Static variable in class org.apache.pig.data.BinInterSedes
 
BooleanGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.BooleanGroovyAlgebraicEvalFunc
 
BooleanSchema - Static variable in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
 
BoundScript - Class in org.apache.pig.scripting
This represents an instance of a bound pipeline.
box(DataBag) - Method in class org.apache.pig.data.SchemaTuple
 
box(Map<String, Object>) - Method in class org.apache.pig.data.SchemaTuple
 
box(byte[]) - Method in class org.apache.pig.data.SchemaTuple
 
box(String) - Method in class org.apache.pig.data.SchemaTuple
 
box(Tuple) - Method in class org.apache.pig.data.SchemaTuple
 
box(int) - Method in class org.apache.pig.data.SchemaTuple
 
box(long) - Method in class org.apache.pig.data.SchemaTuple
 
box(float) - Method in class org.apache.pig.data.SchemaTuple
 
box(double) - Method in class org.apache.pig.data.SchemaTuple
 
box(boolean) - Method in class org.apache.pig.data.SchemaTuple
 
box(DateTime) - Method in class org.apache.pig.data.SchemaTuple
 
box(BigDecimal) - Method in class org.apache.pig.data.SchemaTuple
 
box(BigInteger) - Method in class org.apache.pig.data.SchemaTuple
 
breadthFirst() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
BroadcastConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
BroadcastConverter(JavaSparkContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.BroadcastConverter
 
broadcastedVariableName - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POBroadcastSpark
 
buffer - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
BufferedPositionedInputStream - Class in org.apache.pig.impl.io
 
BufferedPositionedInputStream(InputStream, long) - Constructor for class org.apache.pig.impl.io.BufferedPositionedInputStream
 
BufferedPositionedInputStream(InputStream) - Constructor for class org.apache.pig.impl.io.BufferedPositionedInputStream
 
BUG - Static variable in exception org.apache.pig.PigException
 
build() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
BuildBloom - Class in org.apache.pig.builtin
Build a bloom filter for use later in Bloom.
BuildBloom(String, String, String, String) - Constructor for class org.apache.pig.builtin.BuildBloom
Build a bloom filter of fixed size and number of hash functions.
BuildBloom(String, String, String) - Constructor for class org.apache.pig.builtin.BuildBloom
Construct a Bloom filter based on expected number of elements and desired accuracy.
BuildBloom.Final - Class in org.apache.pig.builtin
 
BuildBloom.Initial - Class in org.apache.pig.builtin
 
BuildBloom.Intermediate - Class in org.apache.pig.builtin
 
BuildBloomBase<T> - Class in org.apache.pig.builtin
A Base class for BuildBloom and its Algebraic implementations.
BuildBloomBase() - Constructor for class org.apache.pig.builtin.BuildBloomBase
 
BuildBloomBase(String, String, String, String) - Constructor for class org.apache.pig.builtin.BuildBloomBase
 
BuildBloomBase(String, String, String) - Constructor for class org.apache.pig.builtin.BuildBloomBase
 
buildDAG(TezPlanContainerNode, Map<String, LocalResource>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJobCompiler
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.FilterAboveForeach
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.FilterConstantCalculator
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.ForEachConstantCalculator
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.GroupByConstParallelSetter
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.LimitOptimizer
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.LoadTypeCastInserter
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.MergeFilter
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.MergeForEach
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.NestedLimitOptimizer
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.PartitionFilterOptimizer
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.PredicatePushdownOptimizer
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.PushDownForEachFlatten
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.PushUpFilter
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.SplitFilter
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.StreamTypeCastInserter
 
buildPattern() - Method in class org.apache.pig.newplan.logical.rules.WholePlanRule
 
buildPattern() - Method in class org.apache.pig.newplan.optimizer.Rule
Build the pattern that this rule will look for
buildRuleSets() - Method in class org.apache.pig.newplan.logical.optimizer.LogicalPlanOptimizer
 
buildSimpleFuncSpec(String, byte...) - Static method in class org.apache.pig.impl.util.Utils
 
BYTE - Static variable in class org.apache.pig.data.BinInterSedes
 
BYTE - Static variable in class org.apache.pig.data.DataType
 
BYTEARRAY - Static variable in class org.apache.pig.data.BinInterSedes
 
BYTEARRAY - Static variable in class org.apache.pig.data.DataType
 
BYTES_PER_REDUCER_PARAM - Static variable in interface org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigReducerEstimator
 
BytesHelper - Class in org.apache.pig.data.utils
 
BytesHelper() - Constructor for class org.apache.pig.data.utils.BytesHelper
 
BytesSchema - Static variable in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
 
bytesToBag(byte[], ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
NOT IMPLEMENTED
bytesToBag(byte[], ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
NOT IMPLEMENTED
bytesToBag(byte[], ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not support conversion to Bag
bytesToBag(byte[], ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToBag(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
bytesToBag(byte[], ResourceSchema.ResourceFieldSchema) - Method in interface org.apache.pig.LoadCaster
Cast data from bytearray to bag value.
bytesToBigCharArray(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
bytesToBigDecimal(byte[]) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
bytesToBigDecimal(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
Not implemented!
bytesToBigDecimal(byte[]) - Method in class org.apache.pig.builtin.TextLoader
 
bytesToBigDecimal(byte[]) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToBigDecimal(byte[]) - Method in interface org.apache.pig.LoadCaster
Cast data from bytearray to BigDecimal value.
bytesToBigInteger(byte[]) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
bytesToBigInteger(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
Not implemented!
bytesToBigInteger(byte[]) - Method in class org.apache.pig.builtin.TextLoader
 
bytesToBigInteger(byte[]) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToBigInteger(byte[]) - Method in interface org.apache.pig.LoadCaster
Cast data from bytearray to BigInteger value.
bytesToBoolean(byte[]) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
bytesToBoolean(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
bytesToBoolean(byte[]) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not support conversion to Boolean
bytesToBoolean(byte[]) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToBoolean(byte[]) - Method in interface org.apache.pig.LoadCaster
Cast data from bytearray to boolean value.
bytesToCharArray(byte[]) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
bytesToCharArray(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
bytesToCharArray(byte[]) - Method in class org.apache.pig.builtin.TextLoader
Cast data from bytes to chararray value.
bytesToCharArray(byte[]) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToCharArray(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
bytesToCharArray(byte[]) - Method in interface org.apache.pig.LoadCaster
Cast data from bytearray to chararray value.
bytesToDateTime(byte[]) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
NOT IMPLEMENTED
bytesToDateTime(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
NOT IMPLEMENTED
bytesToDateTime(byte[]) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not support conversion to DateTime
bytesToDateTime(byte[]) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToDateTime(byte[]) - Method in interface org.apache.pig.LoadCaster
Cast data from bytearray to datetime value.
bytesToDouble(byte[]) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
bytesToDouble(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
bytesToDouble(byte[]) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not support conversion to Double
bytesToDouble(byte[]) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToDouble(byte[]) - Method in interface org.apache.pig.LoadCaster
Cast data from bytearray to double value.
bytesToFloat(byte[]) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
bytesToFloat(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
bytesToFloat(byte[]) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not support conversion to Float
bytesToFloat(byte[]) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToFloat(byte[]) - Method in interface org.apache.pig.LoadCaster
Cast data from bytearray to float value.
bytesToInteger(byte[]) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
bytesToInteger(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
bytesToInteger(byte[]) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not support conversion to Integer
bytesToInteger(byte[]) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToInteger(byte[]) - Method in interface org.apache.pig.LoadCaster
Cast data from bytearray to integer value.
bytesToInternalMap(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
bytesToLong(byte[]) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
bytesToLong(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
bytesToLong(byte[]) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not support conversion to Long
bytesToLong(byte[]) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToLong(byte[]) - Method in interface org.apache.pig.LoadCaster
Cast data from bytearray to long value.
bytesToMap(byte[], ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
NOT IMPLEMENTED
bytesToMap(byte[], ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
bytesToMap(byte[], ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.builtin.TextLoader
 
bytesToMap(byte[], ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToMap(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
bytesToMap(byte[], ResourceSchema.ResourceFieldSchema) - Method in interface org.apache.pig.LoadCaster
Cast data from bytearray to map value.
bytesToTuple(byte[], ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
NOT IMPLEMENTED
bytesToTuple(byte[], ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
NOT IMPLEMENTED
bytesToTuple(byte[], ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not support conversion to Tuple
bytesToTuple(byte[], ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToTuple(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
bytesToTuple(byte[], int, int, byte) - Static method in class org.apache.pig.impl.util.StorageUtil
Transform bytes from a byte array up to the specified length to a Tuple
bytesToTuple(byte[], ResourceSchema.ResourceFieldSchema) - Method in interface org.apache.pig.LoadCaster
Cast data from bytearray to tuple value.
bytesToWritable(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
BZip2CodecWithExtensionBZ - Class in org.apache.pig.impl.io.compress
 
BZip2CodecWithExtensionBZ() - Constructor for class org.apache.pig.impl.io.compress.BZip2CodecWithExtensionBZ
 

C

cache(String, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.ObjectCache
Convenience method to cache objects in ObjectRegistry for a vertex
calcCastString() - Method in class org.apache.pig.ResourceSchema.ResourceFieldSchema
 
calculateMedianValue(List<Long>) - Method in class org.apache.pig.tools.pigstats.JobStats
Calculate the median value from the given array
calculateProgress(JobControl) - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
Compute the progress of the current job submitted through the JobControl object jc to the JobClient jobClient
call() - Method in class org.apache.pig.tools.parameters.PreprocessorContext.CallableStreamReader
 
CallableStreamReader(InputStream) - Constructor for class org.apache.pig.tools.parameters.PreprocessorContext.CallableStreamReader
 
CALLER_CONTEXT - Static variable in class org.apache.pig.backend.hadoop.PigATSClient
 
CALLER_ID - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
use PigConfiguration.PIG_LOG_TRACE_ID instead. Will be removed in Pig 0.18
canonicalName - Variable in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Canonical name.
CanonicalNamer - Class in org.apache.pig.impl.logicalLayer
A visitor to walk the logical plan and give canonical names fields.
CanonicalNamer() - Constructor for class org.apache.pig.impl.logicalLayer.CanonicalNamer
 
canonicalNamer - Static variable in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Canonical namer object to generate new canonical names on request.
canPushDown() - Method in class org.apache.pig.newplan.FilterExtractor
 
capacity() - Method in class org.apache.pig.PigServer
Returns the unused byte capacity of an HDFS filesystem.
CARRIAGE_RETURN - Static variable in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
cast() - Method in class org.apache.pig.impl.plan.ProjectionMap.Column
Check if the column is cast
castable(byte, byte) - Static method in class org.apache.pig.data.DataType
Test if one type can cast to the other.
castable(Schema, Schema) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
Recursively compare two schemas to check if the input schema can be cast to the cast schema
castable(Schema.FieldSchema, Schema.FieldSchema) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Recursively compare two schemas to check if the input schema can be cast to the cast schema
castable(LogicalSchema, LogicalSchema) - Static method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Recursively compare two schemas to check if the input schema can be cast to the cast schema
castable(LogicalSchema.LogicalFieldSchema, LogicalSchema.LogicalFieldSchema) - Static method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
Check if FieldSchema inFs is castable to outFs
caster - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
caster - Variable in class org.apache.pig.builtin.PigStorage
 
CASTER_OPTION - Static variable in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
CastExpression - Class in org.apache.pig.newplan.logical.expression
 
CastExpression(OperatorPlan, LogicalExpression, LogicalSchema.LogicalFieldSchema) - Constructor for class org.apache.pig.newplan.logical.expression.CastExpression
 
CastLineageSetter - Class in org.apache.pig.newplan.logical.visitor
Find uid lineage information.
CastLineageSetter(LogicalPlan, CompilationMessageCollector) - Constructor for class org.apache.pig.newplan.logical.visitor.CastLineageSetter
 
CastUtils - Class in org.apache.pig.impl.util
 
CastUtils() - Constructor for class org.apache.pig.impl.util.CastUtils
 
CBRT - Class in org.apache.pig.builtin
CBRT implements a binding to the Java function Math.cbrt(double) for computing the cube root of the argument.
CBRT() - Constructor for class org.apache.pig.builtin.CBRT
 
CBRT - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use CBRT
CBRT() - Constructor for class org.apache.pig.piggybank.evaluation.math.CBRT
Deprecated.
 
CEIL - Class in org.apache.pig.builtin
CEIL implements a binding to the Java function Math.ceil(double).
CEIL() - Constructor for class org.apache.pig.builtin.CEIL
 
CEIL - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use CEIL
CEIL() - Constructor for class org.apache.pig.piggybank.evaluation.math.CEIL
Deprecated.
 
ceilingCheck() - Method in class org.apache.pig.pen.Illustrator
 
changeFunc(POForEach, byte) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil
Change the algebriac function type for algebraic functions in map and combine In map and combine the algebraic functions will be leaf of the plan
changes() - Method in class org.apache.pig.impl.plan.ProjectionMap
 
CHARARRAY - Static variable in class org.apache.pig.data.BinInterSedes
 
CHARARRAY - Static variable in class org.apache.pig.data.DataType
 
ChararrayGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.ChararrayGroovyAlgebraicEvalFunc
 
ChararrayJrubyAlgebraicEvalFunc(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.ChararrayJrubyAlgebraicEvalFunc
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.AddForEach.AddForEachTransformer
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.ColumnMapKeyPrune.ColumnMapKeyPruneTransformer
 
check() - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneHelper
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.ConstantCalculator.ConstantCalculatorTransformer
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.FilterAboveForeach.FilterAboveForEachTransformer
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.GroupByConstParallelSetter.GroupAllParallelSetterTransformer
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.LimitOptimizer.OptimizeLimitTransformer
 
check() - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.MergeFilter.MergeFilterTransformer
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.MergeForEach.MergeForEachTransformer
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.NestedLimitOptimizer.OptimizeNestedLimitTransformer
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.PartitionFilterOptimizer.PartitionFilterPushDownTransformer
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.PushUpFilter.PushUpFilterTransformer
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.SplitFilter.SplitFilterTransformer
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.TypeCastInserter.TypeCastInserterTransformer
 
check(OperatorPlan) - Method in class org.apache.pig.newplan.optimizer.Transformer
check if the transform should be done.
checkBagType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
checkEquality(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
Do some basic equality checks on two relational operators.
checkExit(int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.RunJarSecurityManager
 
checkLeafIsStore(PhysicalPlan, PigContext) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
 
checkNullAndClass(Object, Object) - Static method in class org.apache.pig.impl.util.Utils
This method is a helper for classes to implement Object.equals(java.lang.Object) The method checks whether the two arguments are both null or both not null and whether they are of the same class
checkNullEquals(Object, Object, boolean) - Static method in class org.apache.pig.impl.util.Utils
This method is a helper for classes to implement Object.equals(java.lang.Object) checks if two objects are equals - two levels of checks are made - first if both are null or not null.
checkOutputSpecs(JobContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
 
checkPermission(Permission) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.RunJarSecurityManager
 
checkPushDown(LogicalExpression) - Method in class org.apache.pig.newplan.FilterExtractor
 
checkPushDown(BinaryExpression) - Method in class org.apache.pig.newplan.FilterExtractor
 
checkPushDown(UnaryExpression) - Method in class org.apache.pig.newplan.FilterExtractor
 
checkPushDown(ProjectExpression) - Method in class org.apache.pig.newplan.FilterExtractor
 
checkPushDown(ProjectExpression) - Method in class org.apache.pig.newplan.PartitionFilterExtractor
 
checkPushDown(ProjectExpression) - Method in class org.apache.pig.newplan.PredicatePushDownFilterExtractor
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.builtin.AvroStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.builtin.BinStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.builtin.JsonStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.builtin.mock.Storage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.builtin.OrcStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.builtin.PigStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.impl.io.InterStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.impl.io.TFileStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
Append newly specified schema
checkSchema(ResourceSchema) - Method in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.piggybank.storage.DBStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.piggybank.storage.FixedWidthStorer
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.piggybank.storage.HiveColumnarStorage
 
checkSchema(ResourceSchema) - Method in class org.apache.pig.StoreFunc
Set the schema for data to be stored.
checkSchema(ResourceSchema) - Method in interface org.apache.pig.StoreFuncInterface
Set the schema for data to be stored.
checkSchema(ResourceSchema) - Method in class org.apache.pig.StoreFuncWrapper
 
checkScript(String) - Method in class org.apache.pig.tools.grunt.Grunt
 
CHILD_JAVA_OPTS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
cleanup() - Method in interface org.apache.pig.Accumulator
Called after getValue() to prepare processing for next key.
cleanup() - Method in class org.apache.pig.AccumulatorEvalFunc
 
cleanup() - Method in class org.apache.pig.AlgebraicEvalFunc
Per the Accumulator interface, this clears all of the variables used in the implementation.
cleanUp() - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchPOStoreImpl
 
cleanUp() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReducePOStoreImpl
 
cleanup(Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
Will be called once all the intermediate keys and values are processed.
cleanup(Mapper<Text, Tuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
Will be called when all the tuples in the input are done.
cleanup(Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
Will be called once all the intermediate keys and values are processed.
cleanUp() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
To perform cleanup when there is an error.
cleanUp() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStoreImpl
To perform cleanup when there is an error.
cleanup(int) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
cleanup() - Method in class org.apache.pig.builtin.AlgebraicBigDecimalMathBase
 
cleanup() - Method in class org.apache.pig.builtin.AlgebraicBigIntegerMathBase
 
cleanup() - Method in class org.apache.pig.builtin.AlgebraicByteArrayMathBase
 
cleanup() - Method in class org.apache.pig.builtin.AlgebraicDoubleMathBase
 
cleanup() - Method in class org.apache.pig.builtin.AlgebraicFloatMathBase
 
cleanup() - Method in class org.apache.pig.builtin.AlgebraicIntMathBase
 
cleanup() - Method in class org.apache.pig.builtin.AlgebraicLongMathBase
 
cleanup() - Method in class org.apache.pig.builtin.AVG
 
cleanup() - Method in class org.apache.pig.builtin.BigDecimalAvg
 
cleanup() - Method in class org.apache.pig.builtin.BigIntegerAvg
 
cleanup() - Method in class org.apache.pig.builtin.COUNT
 
cleanup() - Method in class org.apache.pig.builtin.COUNT_STAR
 
cleanup() - Method in class org.apache.pig.builtin.DateTimeMax
 
cleanup() - Method in class org.apache.pig.builtin.DateTimeMin
 
cleanup() - Method in class org.apache.pig.builtin.DoubleAvg
 
cleanup() - Method in class org.apache.pig.builtin.FloatAvg
 
cleanup() - Method in class org.apache.pig.builtin.IntAvg
 
cleanup() - Method in class org.apache.pig.builtin.LongAvg
 
cleanup() - Method in class org.apache.pig.builtin.StringMax
 
cleanup() - Method in class org.apache.pig.builtin.StringMin
 
cleanup() - Method in class org.apache.pig.builtin.TOP
 
cleanup() - Method in class org.apache.pig.IteratingAccumulatorEvalFunc
 
cleanup() - Method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
 
cleanup() - Method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField
 
cleanup() - Method in class org.apache.pig.scripting.groovy.GroovyAccumulatorEvalFunc
 
cleanup() - Method in class org.apache.pig.scripting.jruby.JrubyAccumulatorEvalFunc
 
cleanupJob(JobContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
cleanupOnFailure(String, Job) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
cleanupOnFailure(String, Job) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
cleanupOnFailure(String, Job) - Method in class org.apache.pig.builtin.AvroStorage
 
cleanupOnFailure(String, Job) - Method in class org.apache.pig.builtin.BinStorage
 
cleanupOnFailure(String, Job) - Method in class org.apache.pig.builtin.mock.Storage
 
cleanupOnFailure(String, Job) - Method in class org.apache.pig.builtin.OrcStorage
 
cleanupOnFailure(String, Job) - Method in class org.apache.pig.builtin.PigStorage
 
cleanupOnFailure(String, Job) - Method in class org.apache.pig.impl.io.InterStorage
 
cleanupOnFailure(String, Job) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
cleanupOnFailure(String, Job) - Method in class org.apache.pig.impl.io.TFileStorage
 
cleanupOnFailure(String, Job) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
cleanupOnFailure(String, Job) - Method in class org.apache.pig.StoreFunc
This method will be called by Pig if the job which contains this store fails.
cleanupOnFailure(String, Job) - Method in interface org.apache.pig.StoreFuncInterface
This method will be called by Pig if the job which contains this store fails.
cleanupOnFailure(String, Job) - Method in class org.apache.pig.StoreFuncWrapper
 
cleanupOnFailureImpl(String, Job) - Static method in class org.apache.pig.StoreFunc
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.builtin.AvroStorage
 
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.builtin.BinStorage
 
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.builtin.mock.Storage
 
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.builtin.OrcStorage
 
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.builtin.PigStorage
 
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.impl.io.InterStorage
 
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.impl.io.TFileStorage
 
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.StoreFunc
This method will be called by Pig if the job which contains this store is successful, and some cleanup of intermediate resources is required.
cleanupOnSuccess(String, Job) - Method in interface org.apache.pig.StoreFuncInterface
This method will be called by Pig if the job which contains this store is successful, and some cleanup of intermediate resources is required.
cleanupOnSuccess(String, Job) - Method in class org.apache.pig.StoreFuncWrapper
 
cleanupOutput(POStore, Job) - Method in class org.apache.pig.builtin.PigStorage
 
cleanupOutput(POStore, Job) - Method in interface org.apache.pig.OverwritableStoreFunc
This method is called to cleanup the store/output location of this StoreFunc.
cleanupStaticData() - Method in class org.apache.pig.JVMReuseImpl
 
clear() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.AccumulativeTupleBuffer
Clear internal buffer, this should be called after all data are retreived
clear() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage.POPackageTupleBuffer
 
clear() - Method in class org.apache.pig.data.AccumulativeBag
 
clear() - Method in interface org.apache.pig.data.DataBag
Clear out the contents of the bag, both on disk and in memory.
clear() - Method in class org.apache.pig.data.DefaultAbstractBag
Clear out the contents of the bag, both on disk and in memory.
clear() - Method in class org.apache.pig.data.InternalCachedBag
 
clear() - Method in class org.apache.pig.data.LimitedSortedDataBag
Clear out the contents of the bag, both on disk and in memory.
clear() - Method in class org.apache.pig.data.NonSpillableDataBag
 
clear() - Method in class org.apache.pig.data.ReadOnceBag
 
clear() - Method in class org.apache.pig.data.SingleTupleBag
 
clear() - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
clear() - Method in class org.apache.pig.impl.util.avro.AvroMapWrapper
 
clear() - Method in class org.apache.pig.impl.util.IdentityHashSet
 
clear() - Method in class org.apache.pig.impl.util.MultiMap
 
clear() - Method in class org.apache.pig.scripting.jruby.RubyDataBag
This method deletes all of the entries in the underlying DataBag.
clearDone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
 
clearMark() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl.IllustratorValueIterator
 
clearSpillables() - Method in class org.apache.pig.impl.util.SpillableMemoryManager
 
clearUnset(Configuration, Map<String, String>) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
Replaces the given entries in the configuration by clearing the Configuration and re-adding the elements that aren't in the Map of entries to unset
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnChainInfo
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnInfo
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.EqualToExpr
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
Make a deep copy of this operator.
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GreaterThanExpr
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GTOrEqualToExpr
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LessThanExpr
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LTOrEqualToExpr
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Mod
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.NotEqualToExpr
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POAnd
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POIsNull
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONot
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POOr
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORegexp
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORelationToExprProject
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
Make a copy of this operator.
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.LitePackager
Make a deep copy of this operator.
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
Make a deep copy of this operator.
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
Make a deep copy of this operator.
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POOptimizedForEach
Make a deep copy of this operator.
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
Make a deep copy of this operator.
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartitionRearrange
Make a deep copy of this operator.
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBloomFilterRearrangeTez
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POFRJoinTez
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POPartitionRearrangeTez
 
clone() - Method in class org.apache.pig.FuncSpec
 
clone() - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
clone() - Method in class org.apache.pig.impl.io.PigNullableWritable
 
clone() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Make a deep copy of a schema.
clone() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Make a deep copy of this FieldSchema and return it.
clone() - Method in class org.apache.pig.impl.plan.Operator
 
clone() - Method in class org.apache.pig.impl.streaming.StreamingCommand
 
clone() - Method in class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
 
clone() - Method in class org.apache.pig.impl.util.UDFContext
Make a shallow copy of the context.
clone() - Method in class org.apache.pig.ResourceStatistics
 
clone(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubyDataBag
This method returns a copy of the encapsulated DataBag.
clone(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubySchema
 
cloneHelper(BinaryComparisonOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryComparisonOperator
 
cloneHelper(BinaryExpressionOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
cloneHelper(UnaryComparisonOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryComparisonOperator
 
cloneHelper(UnaryExpressionOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryExpressionOperator
 
cloneHelper(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
clonePlans(List<PhysicalPlan>) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
cloneUid() - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
close() - Method in interface org.apache.pig.backend.datastorage.DataStorage
Clean-up and releasing of resources.
close() - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
close() - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
close(TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat.PigRecordWriter
 
close() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigRecordReader
 
close() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
close() - Method in class org.apache.pig.backend.hadoop.streaming.HadoopExecutableManager
 
close() - Method in class org.apache.pig.impl.builtin.DefaultIndexableLoader
 
close() - Method in class org.apache.pig.impl.io.BinStorageRecordReader
 
close(TaskAttemptContext) - Method in class org.apache.pig.impl.io.BinStorageRecordWriter
 
close() - Method in class org.apache.pig.impl.io.BufferedPositionedInputStream
 
close() - Method in class org.apache.pig.impl.io.FileLocalizer.DataStorageInputStreamIterator
 
close() - Method in class org.apache.pig.impl.io.InterRecordReader
 
close(TaskAttemptContext) - Method in class org.apache.pig.impl.io.InterRecordWriter
 
close() - Method in class org.apache.pig.impl.io.TFileRecordReader
 
close(TaskAttemptContext) - Method in class org.apache.pig.impl.io.TFileRecordWriter
 
close(Process) - Method in class org.apache.pig.impl.streaming.DefaultInputHandler
 
close() - Method in class org.apache.pig.impl.streaming.ExecutableManager
Close and cleanup the ExecutableManager.
close(Process) - Method in class org.apache.pig.impl.streaming.FileInputHandler
 
close(Process) - Method in class org.apache.pig.impl.streaming.InputHandler
Close the InputHandler since there is no more input to be sent to the managed process.
close() - Method in class org.apache.pig.impl.streaming.OutputHandler
Close the OutputHandler.
close() - Method in class org.apache.pig.impl.util.avro.AvroArrayReader
 
close() - Method in class org.apache.pig.impl.util.avro.AvroRecordReader
 
close(TaskAttemptContext) - Method in class org.apache.pig.impl.util.avro.AvroRecordWriter
 
close() - Method in interface org.apache.pig.IndexableLoadFunc
A method called by the Pig runtime to give an opportunity for implementations to perform cleanup actions like closing the underlying input stream.
close() - Method in class org.apache.pig.pen.FakeRawKeyValueIterator
 
close() - Method in class org.apache.pig.piggybank.storage.AllLoader.AllReader
 
close() - Method in class org.apache.pig.piggybank.storage.avro.AvroStorageInputStream
 
close() - Method in class org.apache.pig.piggybank.storage.avro.PigAvroRecordReader
 
close(TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroRecordWriter
 
close(TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCOutputFormat.Writer
 
close() - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCRecordReader
 
close() - Method in class org.apache.pig.piggybank.storage.IndexedStorage
 
close() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader
 
close() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.IndexedStorageLineReader
Close the underlying stream.
close(TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageOutputFormat.IndexedStorageRecordWriter
 
Close() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Close the index file
close() - Method in class org.apache.pig.piggybank.storage.XMLLoader.XMLRecordReader
 
closePlan() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.XMLMRPrinter
 
closePlan() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.XMLSparkPrinter
 
CmdLineParser - Class in org.apache.pig.tools.cmdline
 
CmdLineParser(String[]) - Constructor for class org.apache.pig.tools.cmdline.CmdLineParser
 
CmdLineParser.ValueExpected - Enum in org.apache.pig.tools.cmdline
 
collect(Mapper<Text, Tuple, PigNullableWritable, Writable>.Context, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
 
collect(Mapper<Text, Tuple, PigNullableWritable, Writable>.Context, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Map
 
collect(Mapper<Text, Tuple, PigNullableWritable, Writable>.Context, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.MapWithComparator
 
collect(Mapper<Text, Tuple, PigNullableWritable, Writable>.Context, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.MapWithPartitionIndex
 
collect(Mapper<Text, Tuple, PigNullableWritable, Writable>.Context, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapOnly.Map
 
collect(Mapper<Text, Tuple, PigNullableWritable, Writable>.Context, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter.PigMapCounter
While tuples are collected, they are counted one by one by a global counter per task.
collect(String, CompilationMessageCollector.MessageType) - Method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
collect(String, CompilationMessageCollector.MessageType, Enum) - Method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
CollectableLoadFunc - Interface in org.apache.pig
This interface implemented by a LoadFunc implementations indicates to Pig that it has the capability to load data such that all instances of a key will occur in same split.
CollectedGroupConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
CollectedGroupConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.CollectedGroupConverter
 
collectStats(JobMetricsListener) - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
COLON - Static variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
Column - Class in org.apache.pig.backend.hadoop.accumulo
Extracts necessary information from a user provide column "specification": colf[[*]:[colq[*]]] Removes any trailing asterisk on colfam or colqual, and appropriately sets the {#link Column.Type}
Column(String) - Constructor for class org.apache.pig.backend.hadoop.accumulo.Column
 
Column(String) - Constructor for class org.apache.pig.Expression.Column
 
Column(Pair<Integer, Integer>) - Constructor for class org.apache.pig.impl.plan.ProjectionMap.Column
 
Column(Pair<Integer, Integer>, boolean, byte) - Constructor for class org.apache.pig.impl.plan.ProjectionMap.Column
 
Column.Type - Enum in org.apache.pig.backend.hadoop.accumulo
 
COLUMN_IGNORE_WHITESPACE_OPTION - Static variable in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
COLUMN_SEPARATOR_OPTION - Static variable in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
ColumnAliasConversionVisitor - Class in org.apache.pig.newplan.logical.visitor
Logical plan visitor which will convert all column alias references to column indexes, using the underlying anonymous expression plan visitor.
ColumnAliasConversionVisitor(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.ColumnAliasConversionVisitor
 
ColumnChainInfo - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
ColumnChainInfo() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnChainInfo
 
ColumnExpression - Class in org.apache.pig.newplan.logical.expression
Super class for all column expressions, including projection, constants, and deferences.
ColumnExpression(String, OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.expression.ColumnExpression
 
ColumnInfo - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
ColumnInfo(List<Integer>, byte) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnInfo
 
ColumnInfo(int, byte) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnInfo
Constructor for range projection or project-star
ColumnInfo(String) - Constructor for class org.apache.pig.backend.hadoop.hbase.HBaseStorage.ColumnInfo
 
ColumnMapKeyPrune - Class in org.apache.pig.newplan.logical.rules
This Rule prunes columns and map keys and set to loader.
ColumnMapKeyPrune(String) - Constructor for class org.apache.pig.newplan.logical.rules.ColumnMapKeyPrune
 
ColumnMapKeyPrune.ColumnMapKeyPruneTransformer - Class in org.apache.pig.newplan.logical.rules
 
ColumnMapKeyPruneTransformer() - Constructor for class org.apache.pig.newplan.logical.rules.ColumnMapKeyPrune.ColumnMapKeyPruneTransformer
 
ColumnPruneHelper - Class in org.apache.pig.newplan.logical.rules
Helper class used by ColumnMapKeyPrune to figure out what columns can be pruned.
ColumnPruneHelper(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.rules.ColumnPruneHelper
 
ColumnPruneVisitor - Class in org.apache.pig.newplan.logical.rules
 
ColumnPruneVisitor(OperatorPlan, Map<LOLoad, Pair<Map<Integer, Set<String>>, Set<Integer>>>, boolean) - Constructor for class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
columns - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
columns - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
columnSeparator - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
combinable() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
Combine() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.DistinctCombiner.Combine
 
Combine() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
 
combine(DataBag) - Static method in class org.apache.pig.builtin.AVG
 
combine(DataBag) - Static method in class org.apache.pig.builtin.BigDecimalAvg
 
combine(DataBag) - Static method in class org.apache.pig.builtin.BigIntegerAvg
 
combine(DataBag) - Static method in class org.apache.pig.builtin.COR
combine results of different data chunk
combine(DataBag) - Static method in class org.apache.pig.builtin.COV
combine results of different data chunk
combine(DataBag) - Static method in class org.apache.pig.builtin.DoubleAvg
 
combine(DataBag) - Static method in class org.apache.pig.builtin.FloatAvg
 
combine(DataBag) - Static method in class org.apache.pig.builtin.IntAvg
 
combine(DataBag) - Static method in class org.apache.pig.builtin.LongAvg
 
combine(DataBag) - Static method in class org.apache.pig.piggybank.evaluation.stats.COR
Deprecated.
combine results of different data chunk
combine(DataBag) - Static method in class org.apache.pig.piggybank.evaluation.stats.COV
Deprecated.
combine results of different data chunk
COMBINE_PLAN - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
CombinedLogLoader - Class in org.apache.pig.piggybank.storage.apachelog
CombinedLogLoader is used to load logs based on Apache's combined log format, based on a format like LogFormat "%h %l %u %t \"%r\" %>s %b \"%{Referer}i\" \"%{User-Agent}i\"" combined The log filename ends up being access_log from a line like CustomLog logs/combined_log combined Example: raw = LOAD 'combined_log' USING org.apache.pig.piggybank.storage.apachelog.CombinedLogLoader AS (remoteAddr, remoteLogname, user, time, method, uri, proto, status, bytes, referer, userAgent);
CombinedLogLoader() - Constructor for class org.apache.pig.piggybank.storage.apachelog.CombinedLogLoader
 
combinePlan - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
combinePlan - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
CombinerOptimizer - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Optimize map reduce plans to use the combiner where possible.
CombinerOptimizer(MROperPlan, boolean) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.CombinerOptimizer
 
CombinerOptimizer(MROperPlan, boolean, CompilationMessageCollector) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.CombinerOptimizer
 
CombinerOptimizer - Class in org.apache.pig.backend.hadoop.executionengine.spark.optimizer
This class goes through the physical plan are replaces GlobalRearrange with ReduceBy where there are algebraic operations.
CombinerOptimizer(SparkOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.CombinerOptimizer
 
CombinerOptimizer - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
Optimize tez plans to use the combiner where possible.
CombinerOptimizer(TezOperPlan, boolean) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.CombinerOptimizer
 
CombinerOptimizer(TezOperPlan, boolean, CompilationMessageCollector) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.CombinerOptimizer
 
CombinerOptimizerUtil - Class in org.apache.pig.backend.hadoop.executionengine.util
 
CombinerOptimizerUtil.DistinctPatcher - Class in org.apache.pig.backend.hadoop.executionengine.util
A visitor to replace Project[bag][*] | |---PODistinct[bag] with POUserFunc(org.apache.pig.builtin.Distinct)[DataBag]
CombinerOptimizerUtil.fixMapProjects - Class in org.apache.pig.backend.hadoop.executionengine.util
 
CombinerPackager - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The package operator that packages the globally rearranged tuples into output format after the combiner stage.
CombinerPackager(Packager, boolean[]) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.CombinerPackager
A new POPostCombinePackage will be constructed as a near clone of the provided POPackage.
combineSmallSplits() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
combineSmallSplits() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
combineSmallSplits() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
COMMA - Static variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
command - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
Command - Class in org.apache.pig.tools.grunt
 
Command() - Constructor for class org.apache.pig.tools.grunt.Command
 
commandLine - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
commandLine - Variable in class org.apache.pig.tools.pigstats.ScriptState
 
commitJob(JobContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
commitJob(JobContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigOutputFormatTez.PigOutputCommitterTez
 
commitTask(TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
CommonLogLoader - Class in org.apache.pig.piggybank.storage.apachelog
CommonLogLoader is used to load logs based on Apache's common log format, based on a format like LogFormat "%h %l %u %t \"%r\" %>s %b" common The log filename ends up being access_log from a line like CustomLog logs/access_log common Example: raw = LOAD 'access_log' USING org.apache.pig.piggybank.storage.apachelog.CommongLogLoader AS (remoteAddr, remoteLogname, user, time, method, uri, proto, bytes);
CommonLogLoader() - Constructor for class org.apache.pig.piggybank.storage.apachelog.CommonLogLoader
 
Comparator() - Constructor for class org.apache.pig.backend.hadoop.BigDecimalWritable.Comparator
 
Comparator() - Constructor for class org.apache.pig.backend.hadoop.BigIntegerWritable.Comparator
 
Comparator() - Constructor for class org.apache.pig.backend.hadoop.DateTimeWritable.Comparator
 
Comparator() - Constructor for class org.apache.pig.backend.hadoop.DoubleWritable.Comparator
 
comparator - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.BigDecimalWritable.Comparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.BigIntegerWritable.Comparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.DateTimeWritable.Comparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.DoubleWritable.Comparator
 
compare(WritableComparable, WritableComparable) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigSecondaryKeyGroupComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigWritableComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBigDecimalRawComparator
Compare two NullableBigDecimalWritables as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBigDecimalRawComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBigIntegerRawComparator
Compare two NullableBigIntegerWritables as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBigIntegerRawComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBooleanRawComparator
Compare two NullableIntWritables as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBooleanRawComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBytesRawComparator
Compare two NullableBytesWritables as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBytesRawComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigDateTimeRawComparator
Compare two NullableIntWritables as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigDateTimeRawComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigDoubleRawComparator
Compare two NullableIntWritables as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigDoubleRawComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigFloatRawComparator
Compare two NullableIntWritables as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigFloatRawComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigIntRawComparator
Compare two NullableIntWritables as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigIntRawComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigLongRawComparator
Compare two NullableIntWritables as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigLongRawComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSecondaryKeyComparator
 
compare(WritableComparable, WritableComparable) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSecondaryKeyComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTextRawComparator
Compare two NullableTextWritables as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTextRawComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleDefaultRawComparator
Compare two NullableTuples as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleDefaultRawComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleSortComparator
Compare two NullableTuples as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleSortComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigDecimalRawBytesComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigDecimalRawBytesPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigDecimalRawBytesPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigDecimalRawPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigDecimalRawPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigIntegerRawBytesComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigIntegerRawBytesPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigIntegerRawBytesPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigIntegerRawPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigIntegerRawPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBooleanRawBytesComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBooleanRawBytesPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBooleanRawBytesPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBooleanRawPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBooleanRawPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBytesRawBytesComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBytesRawBytesPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBytesRawBytesPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBytesRawPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBytesRawPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDateTimeRawBytesComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDateTimeRawBytesPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDateTimeRawBytesPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDateTimeRawPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDateTimeRawPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDoubleRawBytesComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDoubleRawBytesPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDoubleRawBytesPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDoubleRawPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDoubleRawPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigFloatRawBytesComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigFloatRawBytesPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigFloatRawBytesPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigFloatRawPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigFloatRawPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigIntRawBytesComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigIntRawBytesPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigIntRawBytesPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigIntRawPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigIntRawPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigLongRawBytesComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigLongRawBytesPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigLongRawBytesPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigLongRawPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigLongRawPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTextRawBytesComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTextRawBytesPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTextRawBytesPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTextRawPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTextRawPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTupleSortBytesComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTupleSortBytesPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTupleSortBytesPartitionComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTupleSortPartitionComparator
 
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTupleSortPartitionComparator
 
compare(Tuple, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort.SortComparator
 
compare(Tuple, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort.UDFSortComparator
 
compare(WritableComparable, WritableComparable) - Method in class org.apache.pig.ComparisonFunc
Deprecated.
Compare two tuples.
compare(Tuple, Tuple) - Method in class org.apache.pig.ComparisonFunc
Deprecated.
This callback method must be implemented by all subclasses.
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.data.BinInterSedes.BinInterSedesTupleRawComparator
Compare two BinSedesTuples as raw bytes.
compare(WritableComparable, WritableComparable) - Method in class org.apache.pig.data.BinInterSedes.BinInterSedesTupleRawComparator
 
compare(byte[], byte[]) - Static method in class org.apache.pig.data.DataByteArray
 
compare(Object, Object) - Static method in class org.apache.pig.data.DataType
/** Compare two objects to each other.
compare(Object, Object, byte, byte) - Static method in class org.apache.pig.data.DataType
Same as DataType.compare(Object, Object), but does not use reflection to determine the type of passed in objects, relying instead on the caller to provide the appropriate values, as determined by DataType.findType(Object).
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.data.DefaultTuple.DefaultTupleRawComparator
Compare two DefaultTuples as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.data.DefaultTuple.DefaultTupleRawComparator
 
compare(boolean, int, boolean, int) - Method in class org.apache.pig.data.SchemaTuple
 
compare(int, int) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, long, boolean, long) - Method in class org.apache.pig.data.SchemaTuple
 
compare(long, long) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, float, boolean, float) - Method in class org.apache.pig.data.SchemaTuple
 
compare(float, float) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, double, boolean, double) - Method in class org.apache.pig.data.SchemaTuple
 
compare(double, double) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, boolean, boolean, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, byte[], boolean, byte[]) - Method in class org.apache.pig.data.SchemaTuple
 
compare(byte[], byte[]) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, DateTime, boolean, DateTime) - Method in class org.apache.pig.data.SchemaTuple
 
compare(DateTime, DateTime) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, BigDecimal, boolean, BigDecimal) - Method in class org.apache.pig.data.SchemaTuple
 
compare(BigDecimal, BigDecimal) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, BigInteger, boolean, BigInteger) - Method in class org.apache.pig.data.SchemaTuple
 
compare(BigInteger, BigInteger) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, String, boolean, String) - Method in class org.apache.pig.data.SchemaTuple
 
compare(String, String) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, DataBag, boolean, DataBag) - Method in class org.apache.pig.data.SchemaTuple
 
compare(DataBag, DataBag) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, Map<String, Object>, boolean, Map<String, Object>) - Method in class org.apache.pig.data.SchemaTuple
 
compare(Map<String, Object>, Map<String, Object>) - Method in class org.apache.pig.data.SchemaTuple
 
compare(boolean, SchemaTuple<?>, boolean, Object) - Method in class org.apache.pig.data.SchemaTuple
 
compare(IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader, IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.IndexedStorageRecordReaderComparator
 
compare(ThreadContext, IRubyObject, IRubyObject, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubyDataByteArray
This calls to the static method compare of DataByteArray.
compareElementAtPos(int, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareNull(boolean, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
compareNull(boolean, Tuple, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareSize(Tuple) - Method in class org.apache.pig.data.SchemaTuple
 
compareTo(BigDecimalWritable) - Method in class org.apache.pig.backend.hadoop.BigDecimalWritable
 
compareTo(BigIntegerWritable) - Method in class org.apache.pig.backend.hadoop.BigIntegerWritable
 
compareTo(ElementDescriptor) - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
compareTo(Object) - Method in class org.apache.pig.backend.hadoop.DateTimeWritable
 
compareTo(Object) - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
compareTo(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.IndexedKey
 
compareTo(TableSplit) - Method in class org.apache.pig.backend.hadoop.hbase.TableSplitComparable
 
compareTo(Object) - Method in class org.apache.pig.data.AccumulativeBag
 
compareTo(SchemaTuple<?>, boolean) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
compareTo(Object) - Method in class org.apache.pig.data.DataByteArray
Compare two byte arrays.
compareTo(Object) - Method in class org.apache.pig.data.DefaultAbstractBag
This method is potentially very expensive since it may require a sort of the bag; don't call it unless you have to.
compareTo(Object) - Method in class org.apache.pig.data.DefaultTuple
 
compareTo(Object) - Method in class org.apache.pig.data.LimitedSortedDataBag
 
compareTo(Object) - Method in class org.apache.pig.data.NonSpillableDataBag
 
compareTo(Object) - Method in class org.apache.pig.data.ReadOnceBag
 
compareTo(Object) - Method in class org.apache.pig.data.SchemaTuple
 
compareTo(Tuple) - Method in class org.apache.pig.data.SchemaTuple
 
compareTo(Tuple, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
compareTo(SchemaTuple<?>) - Method in class org.apache.pig.data.SchemaTuple
 
compareTo(SchemaTuple<?>, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
compareTo(Object) - Method in class org.apache.pig.data.SingleTupleBag
 
compareTo(Object) - Method in class org.apache.pig.data.TargetedTuple
 
compareTo(Object) - Method in class org.apache.pig.data.UnlimitedNullTuple
 
compareTo(FileSplitComparable) - Method in class org.apache.pig.FileSplitComparable
 
compareTo(Object) - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
compareTo(Object) - Method in class org.apache.pig.impl.io.PigNullableWritable
Compare two nullable objects.
compareTo(Operator) - Method in class org.apache.pig.impl.plan.Operator
 
compareTo(OperatorKey) - Method in class org.apache.pig.impl.plan.OperatorKey
 
compareTo(StreamingCommand.HandleSpec) - Method in class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
 
compareTo(Object) - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
compareTo(Object) - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
compareTo(Object) - Method in class org.apache.pig.pen.util.ExampleTuple
 
compareTo(ThreadContext, IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubyDataByteArray
This calls the compareTo method of the encapsulated DataByteArray.
compareToSpecific(T) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
compareToSpecific(T) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, int, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, long, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, float, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, double, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, boolean, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, byte[], SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, DateTime, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, BigDecimal, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, BigInteger, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, String, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, DataBag, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, Map<String, Object>, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
compareWithElementAtPos(boolean, SchemaTuple<?>, SchemaTuple<?>, int) - Method in class org.apache.pig.data.SchemaTuple
 
ComparisonFunc - Class in org.apache.pig
Deprecated.
ComparisonFunc() - Constructor for class org.apache.pig.ComparisonFunc
Deprecated.
 
ComparisonOperator - Interface in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
This is an interface for all comparison operators.
CompilationMessageCollector - Class in org.apache.pig.impl.plan
This class is used for collecting all messages (error + warning) in compilation process.
CompilationMessageCollector() - Constructor for class org.apache.pig.impl.plan.CompilationMessageCollector
 
CompilationMessageCollector.Message - Class in org.apache.pig.impl.plan
 
CompilationMessageCollector.MessageType - Enum in org.apache.pig.impl.plan
 
CompilationMessageCollector.Unknown - Enum in org.apache.pig.impl.plan
 
compile(LogicalPlan, Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
compile(MROperPlan, String) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
Compiles all jobs that have no dependencies removes them from the plan and returns.
compile(PhysicalPlan, PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceLauncher
 
compile() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
The front-end method that the user calls to compile the plan.
compile() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
compile(PhysicalPlan, PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkLauncher
 
compile() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
The front-end method that the user calls to compile the plan.
compile(TezPlanContainerNode, TezPlanContainer) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJobCompiler
 
compile(PhysicalPlan, PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezLauncher
 
compile(String, JavaCompilerHelper.JavaSourceFromString...) - Method in class org.apache.pig.impl.util.JavaCompilerHelper
 
compile(String) - Static method in class org.apache.pig.scripting.js.JSPig
Define a Pig pipeline.
compile(String, String) - Static method in class org.apache.pig.scripting.js.JSPig
Define a named portion of a Pig pipeline.
compile(String) - Static method in class org.apache.pig.scripting.Pig
Define a Pig pipeline.
compile(String, String) - Static method in class org.apache.pig.scripting.Pig
Define a named portion of a Pig pipeline.
CompiledAutomaton - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex
 
CompiledAutomaton(String) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex.CompiledAutomaton
 
CompiledRegex - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex
 
CompiledRegex(Pattern) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex.CompiledRegex
 
compileFromFile(String) - Static method in class org.apache.pig.scripting.js.JSPig
Define a Pig pipeline based on Pig Latin in a separate file.
compileFromFile(String, String) - Static method in class org.apache.pig.scripting.js.JSPig
Define a named Pig pipeline based on Pig Latin in a separate file.
compileFromFile(String) - Static method in class org.apache.pig.scripting.Pig
Define a Pig pipeline based on Pig Latin in a separate file.
compileFromFile(String, String) - Static method in class org.apache.pig.scripting.Pig
Define a named Pig pipeline based on Pig Latin in a separate file.
CompilerUtils - Class in org.apache.pig.impl.util
 
CompilerUtils() - Constructor for class org.apache.pig.impl.util.CompilerUtils
 
compileSet(String) - Static method in class org.apache.pig.piggybank.storage.hiverc.HiveRCSchemaUtil
Returns a set of columns, with the column names strimmed
complete(String, int, List) - Method in class org.apache.pig.tools.grunt.PigCompletor
 
complete(String, int, List) - Method in class org.apache.pig.tools.grunt.PigCompletorAliases
 
completionNotification(Object) - Method in interface org.apache.pig.backend.executionengine.ExecJob
hook for asynchronous notification of job completion pushed from the back-end
completionNotification(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
COMPRESSION_CODEC_CONF - Static variable in class org.apache.pig.piggybank.storage.hiverc.HiveRCOutputFormat
 
computeAll(DataBag, DataBag) - Static method in class org.apache.pig.builtin.COR
compute sum(XY), sum(X), sum(Y), sum(XX), sum(YY) from given data sets
computeAll(DataBag, DataBag) - Static method in class org.apache.pig.builtin.COV
compute sum(XY), sum(X), sum(Y) from given data sets
computeAll(DataBag, DataBag) - Static method in class org.apache.pig.piggybank.evaluation.stats.COR
Deprecated.
compute sum(XY), sum(X), sum(Y), sum(XX), sum(YY) from given data sets
computeAll(DataBag, DataBag) - Static method in class org.apache.pig.piggybank.evaluation.stats.COV
Deprecated.
compute sum(XY), sum(X), sum(Y) from given data sets
computeSamples(ArrayList<Pair<FileSpec, Boolean>>, PigContext) - Method in class org.apache.pig.impl.builtin.SampleLoader
 
computeTimeSpent(Iterator<TaskReport>) - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
CONCAT - Class in org.apache.pig.builtin
Generates the concatenation of two or more arguments.
CONCAT() - Constructor for class org.apache.pig.builtin.CONCAT
 
conf - Variable in class org.apache.pig.tools.pigstats.JobStats
 
conf_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
ConfigurationUtil - Class in org.apache.pig.backend.hadoop.datastorage
 
ConfigurationUtil() - Constructor for class org.apache.pig.backend.hadoop.datastorage.ConfigurationUtil
 
ConfigurationValidator - Class in org.apache.pig.impl.util
 
ConfigurationValidator() - Constructor for class org.apache.pig.impl.util.ConfigurationValidator
 
configure(POStream) - Method in class org.apache.pig.backend.hadoop.streaming.HadoopExecutableManager
 
configure(POStream) - Method in class org.apache.pig.impl.streaming.ExecutableManager
Configure and initialize the ExecutableManager.
configure(Configuration) - Method in class org.apache.pig.impl.util.SpillableMemoryManager
 
configureCompression(Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
configureInputFormat(Job) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
Method to allow specific implementations to add more elements to the Job for reading data from Accumulo.
configureInputFormat(Job) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorage
 
configureOutputFormat(Job) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
Method to allow specific implementations to add more elements to the Job for writing data to Accumulo.
configureValueOnlyTupleOutput(TezEdgeDescriptor, EdgeProperty.DataMovementType) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
connect(PhysicalOperator, PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
connect(TezOperPlan, TezOperator, TezOperator) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
connect(TezOperPlan, TezOperator, TezOperator, TezEdgeDescriptor) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
connect() - Method in class org.apache.pig.impl.PigContext
 
connect(E, E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Create an edge between two nodes.
connect(Operator, int, Operator, int) - Method in class org.apache.pig.newplan.BaseOperatorPlan
Connect two operators in the plan, controlling which position in the edge lists that the from and to edges are placed.
connect(Operator, Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
Connect two operators in the plan.
connect(Operator, int, Operator, int) - Method in interface org.apache.pig.newplan.OperatorPlan
Connect two operators in the plan, controlling which position in the edge lists that the from and to edges are placed.
connect(Operator, Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
Connect two operators in the plan.
connect(Operator, int, Operator, int) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
connect(Operator, Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
connectedToPackage - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
connectPredecessorsToVertexGroups(TezOperator, TezOperator, PhysicalPlan, TezOperator[], TezOperator[]) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.UnionOptimizer
Connects the unionOp predecessor to the store vertex groups and the output vertex groups and disconnects it from the unionOp.
connectSoftLink() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
connectSoftLink() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
connectTezOpToNewPredecessor(TezOperPlan, TezOperator, TezOperator, TezEdgeDescriptor, String) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
connectTezOpToNewSuccesor(TezOperPlan, TezOperator, TezOperator, TezEdgeDescriptor, String) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
ConsoleReaderInputStream - Class in org.apache.pig.tools.grunt
Borrowed from jline.console.internal.ConsoleReaderInputStream.
ConsoleReaderInputStream(ConsoleReader) - Constructor for class org.apache.pig.tools.grunt.ConsoleReaderInputStream
 
Const(Object) - Constructor for class org.apache.pig.Expression.Const
 
ConstantCalculator - Class in org.apache.pig.newplan.logical.rules
 
ConstantCalculator(String, PigContext) - Constructor for class org.apache.pig.newplan.logical.rules.ConstantCalculator
 
ConstantCalculator.ConstantCalculatorTransformer - Class in org.apache.pig.newplan.logical.rules
 
ConstantCalculator.ConstantCalculatorTransformer.ConstantCalculatorExpressionVisitor - Class in org.apache.pig.newplan.logical.rules
 
ConstantCalculator.ConstantCalculatorTransformer.ConstantCalculatorLogicalPlanVisitor - Class in org.apache.pig.newplan.logical.rules
 
ConstantCalculatorExpressionVisitor(OperatorPlan, LogicalRelationalOperator, PigContext) - Constructor for class org.apache.pig.newplan.logical.rules.ConstantCalculator.ConstantCalculatorTransformer.ConstantCalculatorExpressionVisitor
 
ConstantCalculatorLogicalPlanVisitor(OperatorPlan, PigContext) - Constructor for class org.apache.pig.newplan.logical.rules.ConstantCalculator.ConstantCalculatorTransformer.ConstantCalculatorLogicalPlanVisitor
 
ConstantCalculatorTransformer(List<LogicalRelationalOperator>, PigContext) - Constructor for class org.apache.pig.newplan.logical.rules.ConstantCalculator.ConstantCalculatorTransformer
 
ConstantExpression - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
This class implements a Constant of any type.
ConstantExpression(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
ConstantExpression(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
ConstantExpression - Class in org.apache.pig.newplan.logical.expression
A constant
ConstantExpression(OperatorPlan, Object) - Constructor for class org.apache.pig.newplan.logical.expression.ConstantExpression
Adds expression to the plan
ConstantSize - Class in org.apache.pig.builtin
This method should never be used directly, use SIZE.
ConstantSize() - Constructor for class org.apache.pig.builtin.ConstantSize
 
constExps - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
constructLROutput(List<Result>, List<Result>, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
constructLROutput(List<Result>, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
constructOutput(List<Result>, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
constructPROutput(List<Result>, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartitionRearrange
 
constructPROutput(List<Result>, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POPartitionRearrangeTez
 
consumeInputBag(Result) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
ContainerDescriptor - Interface in org.apache.pig.backend.datastorage
 
contains(Object) - Method in class org.apache.pig.impl.util.IdentityHashSet
 
contains(String) - Static method in enum org.apache.pig.scripting.ScriptEngine.SupportedScriptLang
 
containsAll(Collection<?>) - Method in class org.apache.pig.impl.util.IdentityHashSet
 
containsGenericUnion(Schema) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
determine whether the input schema contains generic unions
containsGenericUnion(Schema, Set<Schema>) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
Called by AvroStorageUtils.containsGenericUnion(Schema) and it recursively checks whether the input schema contains generic unions.
containsKey(Object) - Method in class org.apache.pig.impl.util.avro.AvroMapWrapper
 
containsKey(K) - Method in class org.apache.pig.impl.util.MultiMap
 
containsOutputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
containsOutputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
containsOutputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
containsPhysicalOperator(PhysicalPlan, Class<C>) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.PlanHelper
 
containsRecursiveRecord(Schema) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
determine whether the input schema contains recursive records
containsRecursiveRecord(Schema, Set<String>) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
Called by AvroStorageUtils.containsRecursiveRecord(Schema) and it recursively checks whether the input schema contains recursive records.
containsValue(Object) - Method in class org.apache.pig.impl.util.avro.AvroMapWrapper
 
containsValue(V) - Method in class org.apache.pig.impl.util.MultiMap
 
containUDF() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
check whether this expression contains any UDF this is called if reducer is run as accumulative mode in this case, all UDFs must be called
contentLength - Variable in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
context - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat.RecordReaderFactory
 
context - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter.PigMapCounter
 
context - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter.PigReduceCounter
 
contextSignature - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
convert(Tuple, SchemaTupleFactory) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin.TuplesToSchemaTupleList
 
convert(List<<any>>, POBroadcastSpark) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.BroadcastConverter
 
convert(List<<any>>, POCollectedGroup) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.CollectedGroupConverter
 
convert(List<<any>>, POCounter) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.CounterConverter
 
convert(List<<any>>, PODistinct) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.DistinctConverter
 
convert(List<<any>>, POFilter) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.FilterConverter
 
convert(List<<any>>, POForEach) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.ForEachConverter
 
convert(List<<any>>, POFRJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.FRJoinConverter
 
convert(List<<any>>, POGlobalRearrangeSpark) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.GlobalRearrangeConverter
 
convert(List<<any>>, POJoinGroupSpark) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.JoinGroupSparkConverter
 
convert(List<<any>>, POLimit) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.LimitConverter
 
convert(List<<any>>, POLoad) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.LoadConverter
 
convert(List<<any>>, PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.LocalRearrangeConverter
 
convert(List<<any>>, POMergeCogroup) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.MergeCogroupConverter
 
convert(List<<any>>, POMergeJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.MergeJoinConverter
 
convert(List<<any>>, POPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.PackageConverter
 
convert(List<<any>>, POPoissonSampleSpark) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.PoissonSampleConverter
 
convert(List<<any>>, PORank) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.RankConverter
 
convert(List<<any>>, T) - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.converter.RDDConverter
 
convert(List<<any>>, POReduceBySpark) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.ReduceByConverter
 
convert(List<<any>>, POSkewedJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.SkewedJoinConverter
 
convert(List<<any>>, POSort) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.SortConverter
 
convert(List<<any>>, POSampleSortSpark) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.SparkSampleSortConverter
 
convert(List<<any>>, POSplit) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.SplitConverter
 
convert(List<<any>>, POStore) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.StoreConverter
 
convert(List<<any>>, POStream) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.StreamConverter
 
convert(List<<any>>, POUnion) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.UnionConverter
 
convert(Schema) - Static method in class org.apache.pig.piggybank.storage.avro.AvroSchema2Pig
Convert an Avro schema to a Pig schema
convert(ResourceSchema, boolean) - Static method in class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
Convert a pig ResourceSchema to avro schema
convert(ResourceSchema.ResourceFieldSchema, boolean) - Static method in class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
Convert a Pig ResourceFieldSchema to avro schema
CONVERTED_TO_FETCH - Static variable in class org.apache.pig.impl.PigImplConstants
Used by pig to indicate that current job has been converted to run in fetch mode
CONVERTED_TO_LOCAL - Static variable in class org.apache.pig.impl.PigImplConstants
Used by pig to indicate that current job has been converted to run in local mode
convertHiveToPig(Object, ObjectInspector, boolean[]) - Static method in class org.apache.pig.impl.util.hive.HiveUtils
 
convertNullToUnknown(Tuple) - Static method in class org.apache.pig.builtin.CubeDimensions
 
convertPrimitiveType(byte) - Static method in class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
Convert Pig primitive type to Avro type
convertRecord(ResourceSchema.ResourceFieldSchema[], boolean) - Static method in class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
Convert pig data to Avro record
convertToArray(DataBag) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
convertToType(LoadCaster, byte[], ResourceSchema.ResourceFieldSchema, byte) - Static method in class org.apache.pig.impl.util.CastUtils
 
copy(ElementDescriptor, Properties, boolean) - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
Copy entity from an existing one, possibly residing in a different Data Storage.
copy(ElementDescriptor, boolean) - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
 
copy(ContainerDescriptor, Properties, boolean) - Method in class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
copy(ElementDescriptor, Properties, boolean) - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
copy(ElementDescriptor, boolean) - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
copy(String, String, boolean) - Method in class org.apache.pig.impl.PigContext
 
copyAliasFrom(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
copyAllGeneratedToDistributedCache(PigContext, Configuration) - Static method in class org.apache.pig.data.SchemaTupleFrontend
This must be called when the code has been generated and the generated code needs to be shipped to the cluster, so that it may be used by the mappers and reducers.
copyFeatures(SparkOperator, List<SparkOperator.OPER_FEATURE>) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
copyFeatures(TezOperator, List<TezOperator.OPER_FEATURE>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
copySign - Class in org.apache.pig.piggybank.evaluation.math
math.copySign implements a binding to the Java function Math.copySign(double,double).
copySign() - Constructor for class org.apache.pig.piggybank.evaluation.math.copySign
 
copyTmpFileConfigurationValues(Configuration, Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
 
COR - Class in org.apache.pig.builtin
Computes the correlation between sets of data.
COR() - Constructor for class org.apache.pig.builtin.COR
 
COR(String...) - Constructor for class org.apache.pig.builtin.COR
 
COR - Class in org.apache.pig.piggybank.evaluation.stats
Deprecated.
Use COR
COR() - Constructor for class org.apache.pig.piggybank.evaluation.stats.COR
Deprecated.
 
COR(String...) - Constructor for class org.apache.pig.piggybank.evaluation.stats.COR
Deprecated.
 
COR.Final - Class in org.apache.pig.builtin
 
COR.Final - Class in org.apache.pig.piggybank.evaluation.stats
Deprecated.
 
COR.Initial - Class in org.apache.pig.builtin
 
COR.Initial - Class in org.apache.pig.piggybank.evaluation.stats
Deprecated.
 
COR.Intermed - Class in org.apache.pig.builtin
 
COR.Intermed - Class in org.apache.pig.piggybank.evaluation.stats
Deprecated.
 
CORE_DEFAULT_SITE - Static variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
CORE_SITE - Static variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
COS - Class in org.apache.pig.builtin
COS implements a binding to the Java function Math.cos(double).
COS() - Constructor for class org.apache.pig.builtin.COS
 
COS - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use COS
COS() - Constructor for class org.apache.pig.piggybank.evaluation.math.COS
Deprecated.
 
COSH - Class in org.apache.pig.builtin
COSH implements a binding to the Java function Math.cosh(double).
COSH() - Constructor for class org.apache.pig.builtin.COSH
 
COSH - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use COSH
COSH() - Constructor for class org.apache.pig.piggybank.evaluation.math.COSH
Deprecated.
 
count(Tuple) - Static method in class org.apache.pig.builtin.AVG
 
count(Tuple) - Static method in class org.apache.pig.builtin.BigDecimalAvg
 
count(Tuple) - Static method in class org.apache.pig.builtin.BigIntegerAvg
 
COUNT - Class in org.apache.pig.builtin
Generates the count of the number of values in a bag.
COUNT() - Constructor for class org.apache.pig.builtin.COUNT
 
count(Tuple) - Static method in class org.apache.pig.builtin.DoubleAvg
 
count(Tuple) - Static method in class org.apache.pig.builtin.FloatAvg
 
count(Tuple) - Static method in class org.apache.pig.builtin.IntAvg
 
count(Tuple) - Static method in class org.apache.pig.builtin.LongAvg
 
COUNT.Final - Class in org.apache.pig.builtin
 
COUNT.Initial - Class in org.apache.pig.builtin
 
COUNT.Intermediate - Class in org.apache.pig.builtin
 
COUNT_STAR - Class in org.apache.pig.builtin
Generates the count of the values of the first field of a tuple.
COUNT_STAR() - Constructor for class org.apache.pig.builtin.COUNT_STAR
 
COUNT_STAR.Final - Class in org.apache.pig.builtin
 
COUNT_STAR.Initial - Class in org.apache.pig.builtin
 
COUNT_STAR.Intermediate - Class in org.apache.pig.builtin
 
CounterBasedErrorHandler - Class in org.apache.pig
 
CounterBasedErrorHandler() - Constructor for class org.apache.pig.CounterBasedErrorHandler
 
CounterConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
CounterConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.CounterConverter
 
CountingMap<K> - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners
 
CountingMap() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.CountingMap
 
COV - Class in org.apache.pig.builtin
Computes the covariance between sets of data.
COV() - Constructor for class org.apache.pig.builtin.COV
 
COV(String...) - Constructor for class org.apache.pig.builtin.COV
 
COV - Class in org.apache.pig.piggybank.evaluation.stats
Deprecated.
Use COV
COV() - Constructor for class org.apache.pig.piggybank.evaluation.stats.COV
Deprecated.
 
COV(String...) - Constructor for class org.apache.pig.piggybank.evaluation.stats.COV
Deprecated.
 
COV.Final - Class in org.apache.pig.builtin
 
COV.Final - Class in org.apache.pig.piggybank.evaluation.stats
Deprecated.
 
COV.Initial - Class in org.apache.pig.builtin
 
COV.Initial - Class in org.apache.pig.piggybank.evaluation.stats
Deprecated.
 
COV.Intermed - Class in org.apache.pig.builtin
 
COV.Intermed - Class in org.apache.pig.piggybank.evaluation.stats
Deprecated.
 
create(Properties) - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
Opens a stream onto which an entity can be written to.
create() - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
 
create(Properties) - Method in class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
create(Properties) - Method in class org.apache.pig.backend.hadoop.datastorage.HFile
 
create(Properties) - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
create() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
create(Class<?>[]) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternPlan
This function can be used to create a new PatternPlan if the pattern nodes have at most one parent/child, and they are connected to each other.
create() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTezFactory
 
create(POLocalRearrangeTezFactory.LocalRearrangeType) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTezFactory
 
create(int, POLocalRearrangeTezFactory.LocalRearrangeType) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTezFactory
 
create(int, POLocalRearrangeTezFactory.LocalRearrangeType, List<PhysicalPlan>, byte) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTezFactory
 
create(String, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
create(String, boolean, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
create(Token) - Method in class org.apache.pig.parser.PigParserNodeAdaptor
 
createAccumulatorParam() - Method in class org.apache.pig.tools.pigstats.spark.SparkCounter
 
createAccumulatorParam() - Method in class org.apache.pig.tools.pigstats.spark.SparkCounter.LongSparkCounter
 
createAccumulatorParam() - Method in class org.apache.pig.tools.pigstats.spark.SparkCounter.MapSparkCounter
 
createCl(String) - Method in class org.apache.pig.impl.PigContext
Creates a Classloader based on the passed jarFile and any extra jar files.
createCopy(LOSort) - Static method in class org.apache.pig.newplan.logical.relational.LOSort
 
createCounter(String, T) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounterGroup
 
createCounter(String, Long) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounterGroup.LongSparkCounterGroup
 
createCounter(String, Map<String, Long>) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounterGroup.MapSparkCounterGroup
 
createCounter(Enum<?>) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounters
 
createCounter(String, Enum<?>) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounters
 
createCounter(String, String) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounters
 
createCounter(String, String, Object) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounters
 
createCounter(String, String) - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStatusReporter
 
createDelete(Object, byte, long) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
Public method to initialize a Delete.
createEnum(String, Schema) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumReader
Called to create an enum value.
createExecutableManager() - Method in class org.apache.pig.impl.PigContext
Create a new ExecutableManager depending on the ExecType.
createForEachWithGrpProj(POForEach, byte) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil
Create a new foreach with same scope,alias as given foreach add an inner plan that projects the group column, which is going to be the first input
createIndexerSparkNode(SparkOperator, String, NodeIdGenerator) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkUtil
 
createIndexFile(FileSystem, Path) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Open the index file for writing for given data file
createInputHandler(StreamingCommand) - Static method in class org.apache.pig.impl.streaming.HandlerFactory
Create an InputHandler for the given input specification of the StreamingCommand.
createNumRowTuple(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
createObjectInspector(TypeInfo) - Static method in class org.apache.pig.impl.util.hive.HiveUtils
 
createOperatorKey(String) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil
 
createOutputHandler(StreamingCommand) - Static method in class org.apache.pig.impl.streaming.HandlerFactory
Create an OutputHandler for the given output specification of the StreamingCommand.
createPigScriptUDFJar(PigContext) - Static method in class org.apache.pig.impl.util.JarManager
 
createPlanWithPredecessors(PhysicalOperator, PhysicalPlan) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil
Create new plan and add to it the clones of operator algeOp and its predecessors from the physical plan pplan .
createProcess(StreamingCommand) - Static method in class org.apache.pig.impl.streaming.StreamingUtil
Create an external process for StreamingCommand command.
createPut(Object, byte) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
Public method to initialize a Put.
createRCFileWriter(TaskAttemptContext, Text) - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCOutputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
createRecordReader() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat.RecordReaderFactory
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.running.PigInputFormatSpark
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigInputFormatTez
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.impl.io.BinStorageInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.impl.io.InterStorage.InterInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.impl.io.TFileStorage.TFileInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.AllLoader.AllLoaderInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroInputFormat
Create and return an avro record reader.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCInputFormat
Initialises an instance of HiveRCRecordReader.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat
 
createSoftLink(E, E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Create an soft edge between two nodes.
createSoftLink(Operator, Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
Create an soft edge between two nodes.
createSoftLink(Operator, Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
Create an soft edge between two nodes.
createSoftLink(Operator, Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
createStoreFunc(POStore) - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchPOStoreImpl
 
createStoreFunc(POStore) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReducePOStoreImpl
 
createStoreFunc(POStore) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStoreImpl
Set up the storer
createTuple(Object[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
createTuple(String) - Method in class org.apache.pig.piggybank.storage.XMLLoader
Creates a tuple from a matched string
createUDField(int, Schema) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
create an avro field using the given schema
createUDPartialRecordSchema() - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
create an avro field with null schema (it is a space holder)
CSVExcelStorage - Class in org.apache.pig.piggybank.storage
CSV loading and storing with support for multi-line fields, and escaping of delimiters and double quotes within fields; uses CSV conventions of Excel 2007.
CSVExcelStorage() - Constructor for class org.apache.pig.piggybank.storage.CSVExcelStorage
 
CSVExcelStorage(String) - Constructor for class org.apache.pig.piggybank.storage.CSVExcelStorage
 
CSVExcelStorage(String, String) - Constructor for class org.apache.pig.piggybank.storage.CSVExcelStorage
 
CSVExcelStorage(String, String, String) - Constructor for class org.apache.pig.piggybank.storage.CSVExcelStorage
 
CSVExcelStorage(String, String, String, String) - Constructor for class org.apache.pig.piggybank.storage.CSVExcelStorage
 
CSVExcelStorage.Headers - Enum in org.apache.pig.piggybank.storage
 
CSVExcelStorage.Linebreaks - Enum in org.apache.pig.piggybank.storage
 
CSVExcelStorage.Multiline - Enum in org.apache.pig.piggybank.storage
 
CSVLoader - Class in org.apache.pig.piggybank.storage
A load function based on PigStorage that implements part of the CSV "standard" This loader properly supports double-quoted fields that contain commas and other double-quotes escaped with backslashes.
CSVLoader() - Constructor for class org.apache.pig.piggybank.storage.CSVLoader
 
CubeDimensions - Class in org.apache.pig.builtin
Produces a DataBag with all combinations of the argument tuple members as in a data cube.
CubeDimensions() - Constructor for class org.apache.pig.builtin.CubeDimensions
 
CubeDimensions(String) - Constructor for class org.apache.pig.builtin.CubeDimensions
 
currentConf - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
 
currentOp - Variable in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
currentOp - Variable in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
currentPlan - Variable in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
currentPlan - Variable in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
currentPlan - Variable in class org.apache.pig.newplan.optimizer.Rule
 
currentPlans - Variable in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
currentPlans - Variable in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
currentReaderIndexStart - Variable in class org.apache.pig.piggybank.storage.IndexedStorage
Index into the the list of readers to the current reader.
CurrentTime - Class in org.apache.pig.builtin
 
CurrentTime() - Constructor for class org.apache.pig.builtin.CurrentTime
This is a default constructor for Pig reflection purposes.
currentWalker - Variable in class org.apache.pig.newplan.PlanVisitor
Guaranteed to always point to the walker currently being used.
CustomFormatToISO - Class in org.apache.pig.piggybank.evaluation.datetime.convert
CustomFormatToISO converts arbitrary date formats to ISO format.
CustomFormatToISO() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.convert.CustomFormatToISO
 
customPartitioner - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
customPartitioner - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
customPartitioner - Variable in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 

D

DAG_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
dagCompletedNotification(String, String, boolean, TezDAGStats) - Method in class org.apache.pig.tools.pigstats.tez.PigTezProgressNotificationListener
Invoked just after the Tez DAGs is completed (successful or failed).
dagCompletedNotification(String, TezDAGStats) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState
 
dagLaunchNotification(String, String, OperatorPlan<?>, int) - Method in class org.apache.pig.tools.pigstats.tez.PigTezProgressNotificationListener
Invoked just before launching a Tez DAG spawned by the script.
dagLaunchNotification(String, OperatorPlan<?>, int) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState
 
dagProgressNotification(String, String, int, int) - Method in class org.apache.pig.tools.pigstats.tez.PigTezProgressNotificationListener
Invoked to update the execution progress.
dagProgressNotification(String, int, int) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState
 
dagStartedNotification(String, String, String) - Method in class org.apache.pig.tools.pigstats.tez.PigTezProgressNotificationListener
Invoked after a Tez DAG is started.
dagStartedNotification(String, String) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState
 
DanglingNestedNodeRemover - Class in org.apache.pig.newplan.logical.visitor
 
DanglingNestedNodeRemover(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.DanglingNestedNodeRemover
 
data - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
data - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
Data() - Constructor for class org.apache.pig.builtin.mock.Storage.Data
 
DataBag - Interface in org.apache.pig.data
A collection of Tuples.
DataBagGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.DataBagGroovyAlgebraicEvalFunc
 
DataBagGroovyIterator(Iterator<Tuple>) - Constructor for class org.apache.pig.scripting.groovy.GroovyUtils.DataBagGroovyIterator
 
DataByteArray - Class in org.apache.pig.data
An implementation of byte array.
DataByteArray() - Constructor for class org.apache.pig.data.DataByteArray
Default constructor.
DataByteArray(byte[]) - Constructor for class org.apache.pig.data.DataByteArray
Construct a byte array using the provided bytes as the content.
DataByteArray(DataByteArray, DataByteArray) - Constructor for class org.apache.pig.data.DataByteArray
Construct a byte array concatenating the two provided byte arrays as the content.
DataByteArray(byte[], int, int) - Constructor for class org.apache.pig.data.DataByteArray
Construct a byte array using a portion of the provided bytes as content.
DataByteArray(String) - Constructor for class org.apache.pig.data.DataByteArray
Construct a byte array from a String.
DataByteArrayGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.DataByteArrayGroovyAlgebraicEvalFunc
 
DataByteArrayJrubyAlgebraicEvalFunc(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.DataByteArrayJrubyAlgebraicEvalFunc
 
dataMovementType - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
DataReaderWriter - Class in org.apache.pig.data
This class was used to handle reading and writing of intermediate results of data types.
DataReaderWriter() - Constructor for class org.apache.pig.data.DataReaderWriter
 
dataSourceType - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
DataStorage - Interface in org.apache.pig.backend.datastorage
DataStorage provides an abstraction of a generic container.
DataStorageException - Exception in org.apache.pig.backend.datastorage
 
DataStorageException() - Constructor for exception org.apache.pig.backend.datastorage.DataStorageException
Create a new DataStorageException with null as the error message.
DataStorageException(String) - Constructor for exception org.apache.pig.backend.datastorage.DataStorageException
Create a new DataStorageException with the specified message and cause.
DataStorageException(Throwable) - Constructor for exception org.apache.pig.backend.datastorage.DataStorageException
Create a new DataStorageException with the specified cause.
DataStorageException(String, Throwable) - Constructor for exception org.apache.pig.backend.datastorage.DataStorageException
Create a new DataStorageException with the specified message and cause.
DataStorageException(String, int) - Constructor for exception org.apache.pig.backend.datastorage.DataStorageException
Create a new DataStorageException with the specified message and cause.
DataStorageException(String, int, Throwable) - Constructor for exception org.apache.pig.backend.datastorage.DataStorageException
Create a new DataStorageException with the specified message and cause.
DataStorageException(String, int, byte) - Constructor for exception org.apache.pig.backend.datastorage.DataStorageException
Create a new DataStorageException with the specified message and cause.
DataStorageException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.backend.datastorage.DataStorageException
Create a new DataStorageException with the specified message and cause.
DataStorageException(String, int, boolean) - Constructor for exception org.apache.pig.backend.datastorage.DataStorageException
Create a new DataStorageException with the specified message and cause.
DataStorageException(String, int, byte, boolean) - Constructor for exception org.apache.pig.backend.datastorage.DataStorageException
Create a new DataStorageException with the specified message and cause.
DataStorageException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.backend.datastorage.DataStorageException
Create a new DataStorageException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
DataStorageException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.backend.datastorage.DataStorageException
Create a new DataStorageException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
DataStorageInputStreamIterator(ElementDescriptor[]) - Constructor for class org.apache.pig.impl.io.FileLocalizer.DataStorageInputStreamIterator
 
DataType - Class in org.apache.pig.data
A class of static final values used to encode data type and a number of static helper functions for manipulating data objects.
DataType() - Constructor for class org.apache.pig.data.DataType
 
DATE_FORMAT - Static variable in class org.apache.pig.tools.pigstats.PigStats
 
DATE_RANGE - Static variable in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
DateExtractor - Class in org.apache.pig.piggybank.evaluation.util.apachelogparser
DateExtractor has four different constructors which each allow for different functionality.
DateExtractor() - Constructor for class org.apache.pig.piggybank.evaluation.util.apachelogparser.DateExtractor
forms the formats based on default incomingDateFormat and default outgoingDateFormat
DateExtractor(String) - Constructor for class org.apache.pig.piggybank.evaluation.util.apachelogparser.DateExtractor
forms the formats based on passed outgoingDateString and the default incomingDateFormat
DateExtractor(String, String) - Constructor for class org.apache.pig.piggybank.evaluation.util.apachelogparser.DateExtractor
forms the formats based on passed incomingDateString and outgoingDateString
DateExtractor(String, String, String) - Constructor for class org.apache.pig.piggybank.evaluation.util.apachelogparser.DateExtractor
forms the formats based on passed incomingDateString and outgoingDateString
DATETIME - Static variable in class org.apache.pig.data.BinInterSedes
 
DATETIME - Static variable in class org.apache.pig.data.DataType
 
DateTimeGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.DateTimeGroovyAlgebraicEvalFunc
 
DateTimeMax - Class in org.apache.pig.builtin
This method should never be used directly, use MAX.
DateTimeMax() - Constructor for class org.apache.pig.builtin.DateTimeMax
 
DateTimeMax.Final - Class in org.apache.pig.builtin
 
DateTimeMax.Initial - Class in org.apache.pig.builtin
 
DateTimeMax.Intermediate - Class in org.apache.pig.builtin
 
DateTimeMin - Class in org.apache.pig.builtin
This method should never be used directly, use MAX.
DateTimeMin() - Constructor for class org.apache.pig.builtin.DateTimeMin
 
DateTimeMin.Final - Class in org.apache.pig.builtin
 
DateTimeMin.Initial - Class in org.apache.pig.builtin
 
DateTimeMin.Intermediate - Class in org.apache.pig.builtin
 
DateTimeWritable - Class in org.apache.pig.backend.hadoop
Writable for DateTime values.
DateTimeWritable() - Constructor for class org.apache.pig.backend.hadoop.DateTimeWritable
 
DateTimeWritable(DateTime) - Constructor for class org.apache.pig.backend.hadoop.DateTimeWritable
 
DateTimeWritable.Comparator - Class in org.apache.pig.backend.hadoop
A Comparator optimized for DateTimeWritable.
DaysBetween - Class in org.apache.pig.builtin
DaysBetween returns the number of days between two DateTime objects
DaysBetween() - Constructor for class org.apache.pig.builtin.DaysBetween
 
DBStorage - Class in org.apache.pig.piggybank.storage
 
DBStorage(String, String, String) - Constructor for class org.apache.pig.piggybank.storage.DBStorage
 
DBStorage(String, String, String, String, String) - Constructor for class org.apache.pig.piggybank.storage.DBStorage
 
DBStorage(String, String, String, String, String, String) - Constructor for class org.apache.pig.piggybank.storage.DBStorage
 
debugOff() - Method in class org.apache.pig.PigServer
Set the logging level to the default.
debugOn() - Method in class org.apache.pig.PigServer
Set the logging level to DEBUG.
Decode - Class in org.apache.pig.piggybank.evaluation.decode
Syntax: String Decode(expression, value1, mapping_string1, ..., valueN, mapping_stringN, other_string). Logic: if (expression==value1) return mapping_string1;
......
Decode() - Constructor for class org.apache.pig.piggybank.evaluation.decode.Decode
 
decodeBytes(String) - Static method in class org.apache.pig.impl.util.ObjectSerializer
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.AddExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.AndExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.BinCondExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.CastExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.ConstantExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.DivideExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.EqualExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.GreaterThanEqualExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.GreaterThanExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.IsNullExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.LessThanEqualExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.LessThanExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpression
Create the deep copy of this expression and add that into the passed LogicalExpressionPlan Return the copy of this expression with updated logical expression plan.
deepCopy() - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionPlan
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.MapLookupExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.ModExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.MultiplyExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.NegativeExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.NotEqualExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.NotExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.OrExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.RegexExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.ScalarExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.SubtractExpression
 
deepCopy(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
deepCopy() - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
 
deepCopy() - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
DEFAULT_BLOOM_HASH_TYPE - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
DEFAULT_BLOOM_STRATEGY - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
DEFAULT_BLOOM_VECTOR_SIZE_BYTES - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
DEFAULT_BYTES_PER_REDUCER - Static variable in interface org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigReducerEstimator
 
DEFAULT_CHUNK_SIZE - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.JoinPackager
 
DEFAULT_DATE_TIME_ZONE - Static variable in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOHelper
Default time zone for use in parsing, regardless of System or JDK's default time zone.
DEFAULT_DEFLATE_LEVEL - Static variable in class org.apache.pig.piggybank.storage.avro.PigAvroOutputFormat
The default deflate level.
DEFAULT_DELIMITERS - Static variable in class org.apache.pig.impl.util.StorageUtil
 
DEFAULT_EXTENSION - Static variable in class org.apache.pig.piggybank.storage.hiverc.HiveRCOutputFormat
 
DEFAULT_MAX_REDUCER_COUNT_PARAM - Static variable in interface org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigReducerEstimator
 
DEFAULT_NUM_BLOOM_FILTERS_REDUCE - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
DEFAULT_NUM_BLOOM_HASH_FUNCTIONS - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
DEFAULT_PERCENT_MEMUSAGE - Static variable in class org.apache.pig.impl.builtin.PartitionSkewedKeys
 
DEFAULT_SAMPLE_RATE - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
DEFAULT_SCOPE - Static variable in class org.apache.pig.newplan.PlanVisitor
 
DefaultAbstractBag - Class in org.apache.pig.data
Default implementation of DataBag.
DefaultAbstractBag() - Constructor for class org.apache.pig.data.DefaultAbstractBag
 
DefaultAbstractBag.BagDelimiterTuple - Class in org.apache.pig.data
 
DefaultAbstractBag.EndBag - Class in org.apache.pig.data
 
DefaultAbstractBag.StartBag - Class in org.apache.pig.data
 
DefaultBagFactory - Class in org.apache.pig.data
Default implementation of BagFactory.
DefaultDataBag - Class in org.apache.pig.data
An unordered collection of Tuples (possibly) with multiples.
DefaultDataBag() - Constructor for class org.apache.pig.data.DefaultDataBag
 
DefaultDataBag(List<Tuple>) - Constructor for class org.apache.pig.data.DefaultDataBag
This constructor creates a bag out of an existing list of tuples by taking ownership of the list and NOT copying the contents of the list.
DefaultIndexableLoader - Class in org.apache.pig.impl.builtin
Used by MergeJoin .
DefaultIndexableLoader(String, String, String, String, String) - Constructor for class org.apache.pig.impl.builtin.DefaultIndexableLoader
 
DefaultInputHandler - Class in org.apache.pig.impl.streaming
DefaultInputHandler handles the input for the Pig-Streaming executable in a synchronous manner by feeding it input via its stdin.
DefaultInputHandler() - Constructor for class org.apache.pig.impl.streaming.DefaultInputHandler
 
DefaultInputHandler(StreamingCommand.HandleSpec) - Constructor for class org.apache.pig.impl.streaming.DefaultInputHandler
 
defaultNumGroups - Static variable in class org.apache.pig.impl.builtin.GFAny
 
DefaultOutputHandler - Class in org.apache.pig.impl.streaming
FileOutputHandler handles the output from the Pig-Streaming executable in an synchronous manner by reading its output via its stdout.
DefaultOutputHandler() - Constructor for class org.apache.pig.impl.streaming.DefaultOutputHandler
 
DefaultOutputHandler(StreamingCommand.HandleSpec) - Constructor for class org.apache.pig.impl.streaming.DefaultOutputHandler
 
defaultParallel - Variable in class org.apache.pig.impl.PigContext
 
DefaultTuple - Class in org.apache.pig.data
A default implementation of Tuple.
DefaultTuple() - Constructor for class org.apache.pig.data.DefaultTuple
Default constructor.
DefaultTuple.DefaultTupleRawComparator - Class in org.apache.pig.data
 
DefaultTupleFactory - Class in org.apache.pig.data
Deprecated.
DefaultTupleFactory() - Constructor for class org.apache.pig.data.DefaultTupleFactory
Deprecated.
 
DefaultTupleRawComparator() - Constructor for class org.apache.pig.data.DefaultTuple.DefaultTupleRawComparator
 
define(Ruby) - Static method in class org.apache.pig.scripting.jruby.RubyDataBag
This method registers the class with the given runtime.
define(Ruby) - Static method in class org.apache.pig.scripting.jruby.RubyDataByteArray
Registers the DataByteArray class with the Ruby runtime.
define(Ruby) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This method registers the class with the given runtime.
define(String, String) - Static method in class org.apache.pig.scripting.js.JSPig
See Pig
define(String, String) - Static method in class org.apache.pig.scripting.Pig
Define an alias for a UDF or a streaming command.
DEFLATE_CODEC - Static variable in class org.apache.pig.piggybank.storage.avro.PigAvroOutputFormat
The deflate codec
DEFLATE_LEVEL_KEY - Static variable in class org.apache.pig.piggybank.storage.avro.PigAvroOutputFormat
The configuration key for Avro deflate level.
delete() - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
Remove entity from the Data Storage.
delete() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
delete(String, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
deleteFile(String) - Method in class org.apache.pig.PigServer
Delete a file.
deleteTempFiles() - Static method in class org.apache.pig.impl.io.FileLocalizer
 
deleteTempResourceFiles() - Static method in class org.apache.pig.impl.io.FileLocalizer
 
DependencyOrderWalker<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.impl.plan
DependencyOrderWalker traverses the graph in such a way that no node is visited before all the nodes it depends on have been visited.
DependencyOrderWalker(P) - Constructor for class org.apache.pig.impl.plan.DependencyOrderWalker
 
DependencyOrderWalker(P, boolean) - Constructor for class org.apache.pig.impl.plan.DependencyOrderWalker
 
DependencyOrderWalker - Class in org.apache.pig.newplan
A walker to walk graphs in dependency order.
DependencyOrderWalker(OperatorPlan) - Constructor for class org.apache.pig.newplan.DependencyOrderWalker
 
depthFirstLP() - Method in class org.apache.pig.newplan.logical.optimizer.LogicalPlanPrinter
 
depthFirstPP() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
depthFirstPP(Element) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.XMLPhysicalPlanPrinter
 
depthFirstSearchForFile(FileStatus[], FileSystem) - Static method in class org.apache.pig.impl.util.Utils
Finds a valid path for a file from a FileStatus object.
depthFirstSearchForFile(FileStatus[], FileSystem, PathFilter) - Static method in class org.apache.pig.impl.util.Utils
Finds a valid path for a file from an array of FileStatus objects.
DepthFirstWalker<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.impl.plan
DepthFirstWalker traverses a plan in a depth first manner.
DepthFirstWalker(P) - Constructor for class org.apache.pig.impl.plan.DepthFirstWalker
 
DepthFirstWalker - Class in org.apache.pig.newplan
Do a depth first traversal of the graph.
DepthFirstWalker(OperatorPlan) - Constructor for class org.apache.pig.newplan.DepthFirstWalker
 
DereferenceExpression - Class in org.apache.pig.newplan.logical.expression
get one or elements out of a tuple or a bag in case of Tuple( a#2:int, b#3:bag{ b_a#4:int, b_b#5:float }, c#6:int ) # 1 (the number after # represents the uid) Dereference ( 0 ) --> a:int - dereference of single column in a tuple gives the field Dereference ( 0,2 ) --> Tuple(a#2:int, c#6:int) #7 - dereference of more than one column gives a tuple Dereference ( 1 ) --> Dereference ( 1 ) --> b:bag{b_b#5:float}#8 - dereference of a bag gives a bag
DereferenceExpression(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
DereferenceExpression(OperatorPlan, int) - Constructor for class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
DereferenceExpression(OperatorPlan, List<Integer>) - Constructor for class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
describe(String) - Method in class org.apache.pig.scripting.BoundScript
Describe the schema of an alias in this pipeline.
deserialize(byte[], int, int) - Method in class org.apache.pig.builtin.PigStreaming
 
deserialize(byte[], int, int) - Method in class org.apache.pig.impl.streaming.PigStreamingUDF
 
deserialize(String) - Static method in class org.apache.pig.impl.util.ObjectSerializer
 
deserialize() - Method in class org.apache.pig.impl.util.UDFContext
Populate the udfConfs field.
deserialize(byte[]) - Method in class org.apache.pig.PigStreamingBase
Deprecated.
deserialize(byte[], int, int) - Method in class org.apache.pig.PigStreamingBase
Given a byte array from a streaming executable, produce a tuple.
deserialize(byte[]) - Method in interface org.apache.pig.StreamToPig
Deprecated.
Given a byte array from a streaming executable, produce a tuple.
deserializeForSpark(String, String) - Method in class org.apache.pig.impl.util.UDFContext
 
deserializeJobConf(byte[]) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.KryoSerializer
 
deserializer - Variable in class org.apache.pig.impl.streaming.OutputHandler
 
destroy() - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Perform any cleanup operation
destroy() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
destroy() - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
destroy() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezLauncher
 
detachInput() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
Detaches any tuples that are attached
detachInput() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
detachInput() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
detachInput() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
attachInput's better half!
detailedMessage - Variable in exception org.apache.pig.PigException
 
DETAILS - Static variable in class org.apache.pig.piggybank.storage.avro.AvroStorageLog
 
determineErrorSource(int) - Static method in exception org.apache.pig.PigException
A static method to determine the error source given the error code
determineFieldSchema(ResourceSchema.ResourceFieldSchema) - Static method in class org.apache.pig.data.DataType
Determine the field schema of an ResourceFieldSchema
determineFieldSchema(Object) - Static method in class org.apache.pig.data.DataType
Determine the field schema of an object
determineFirstFile(String) - Method in class org.apache.pig.piggybank.storage.allloader.LoadFuncHelper
If location is a directory the first file found is returned
determineFunction(String) - Method in class org.apache.pig.piggybank.storage.allloader.LoadFuncHelper
If location is a directory the first file found in the directory is used.
The file extension of the file will be searched against the file.extension.loaders mappings.
determineFunction(String, Path) - Method in class org.apache.pig.piggybank.storage.allloader.LoadFuncHelper
The file extension of the file will be searched against the file.extension.loaders mappings.
determineSchema(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.rules.LoadTypeCastInserter
if we are inserting casts in a load and if the loader implements determineSchema(), insert casts only where necessary Note that in this case, the data coming out of the loader is not a BYTEARRAY but is whatever determineSchema() says it is.
determineSchema(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.rules.StreamTypeCastInserter
 
determineSchema(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.rules.TypeCastInserter
 
didFetch - Variable in class org.apache.pig.impl.io.FileLocalizer.FetchFileRet
 
DIFF - Class in org.apache.pig.builtin
DIFF takes two bags as arguments and compares them.
DIFF() - Constructor for class org.apache.pig.builtin.DIFF
 
DiffDate - Class in org.apache.pig.piggybank.evaluation.datetime
Syntax: int DiffDate(String yyyymmdd1, String yyyymmdd2). Input: date string in "yyyymmdd" format. Output: (date1-date2) in days, can be negative.
DiffDate() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.DiffDate
 
disableCounter() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
disableCounter() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
disableCounter() - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit
 
disableCounter() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
disableCounter() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
discardBatch() - Method in class org.apache.pig.PigServer
Discards a batch of Pig commands.
disconnect(TezOperator, TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperPlan
 
disconnect(E, E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Remove an edge from between two nodes.
disconnect(Operator, Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
Disconnect two operators in the plan.
disconnect(Operator, Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
Disconnect two operators in the plan.
disconnect(Operator, Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
DiscreteProbabilitySampleGenerator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners
 
DiscreteProbabilitySampleGenerator(long, float[]) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.DiscreteProbabilitySampleGenerator
 
display() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.CountingMap
 
DisplayExamples - Class in org.apache.pig.pen.util
 
DisplayExamples() - Constructor for class org.apache.pig.pen.util.DisplayExamples
 
displayStatistics() - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
Logs the statistics in the Pig log file at INFO level
distinct - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
Distinct - Class in org.apache.pig.builtin
Find the distinct set of tuples in a bag.
Distinct() - Constructor for class org.apache.pig.builtin.Distinct
 
Distinct.Final - Class in org.apache.pig.builtin
 
Distinct.Initial - Class in org.apache.pig.builtin
 
Distinct.Intermediate - Class in org.apache.pig.builtin
 
DistinctCombiner - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
A special implementation of combiner used only for distinct.
DistinctCombiner() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.DistinctCombiner
 
DistinctCombiner.Combine - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
DistinctConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
DistinctConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.DistinctConverter
 
DistinctDataBag - Class in org.apache.pig.data
An unordered collection of Tuples with no multiples.
DistinctDataBag() - Constructor for class org.apache.pig.data.DistinctDataBag
 
DistinctPatcher(PhysicalPlan, PlanWalker<PhysicalOperator, PhysicalPlan>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil.DistinctPatcher
 
DistinctPatcher(PhysicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil.DistinctPatcher
 
div(BigDecimal, BigDecimal) - Static method in class org.apache.pig.builtin.BigDecimalAvg
 
div(BigInteger, BigInteger) - Static method in class org.apache.pig.builtin.BigIntegerAvg
 
Divide - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
Divide(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
Divide(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
divide(Number, Number, byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
DivideExpression - Class in org.apache.pig.newplan.logical.expression
Divide Operator
DivideExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.DivideExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
doAllPredecessors(O, Set<O>, Collection<O>) - Method in class org.apache.pig.impl.plan.DependencyOrderWalker
 
doAllPredecessors(Operator, Set<Operator>, Collection<Operator>) - Method in class org.apache.pig.newplan.DependencyOrderWalker
 
doAllSuccessors(O, Set<O>, Collection<O>) - Method in class org.apache.pig.impl.plan.ReverseDependencyOrderWalker
 
doAllSuccessors(Operator, Set<Operator>, Collection<Operator>) - Method in class org.apache.pig.newplan.ReverseDependencyOrderWalker
 
doAllSuccessors(Operator, Collection<Operator>) - Method in class org.apache.pig.newplan.ReverseDependencyOrderWalkerWOSeenChk
 
doInsertBetween(E, E, E, boolean) - Method in class org.apache.pig.impl.plan.OperatorPlan
 
doParamSubstitution(InputStream, List<String>, List<String>) - Method in class org.apache.pig.impl.PigContext
 
doParamSubstitution(BufferedReader, List<String>, List<String>) - Method in class org.apache.pig.impl.PigContext
 
doParamSubstitution(BufferedReader) - Method in class org.apache.pig.impl.PigContext
 
doParamSubstitutionOutputToFile(BufferedReader, String, List<String>, List<String>) - Method in class org.apache.pig.impl.PigContext
 
doParamSubstitutionOutputToFile(BufferedReader, String) - Method in class org.apache.pig.impl.PigContext
 
DotLOPrinter - Class in org.apache.pig.newplan.logical
This class can print a logical plan in the DOT format.
DotLOPrinter(BaseOperatorPlan, PrintStream) - Constructor for class org.apache.pig.newplan.logical.DotLOPrinter
 
DotMRPrinter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
This class can print an MR plan in the DOT format.
DotMRPrinter(MROperPlan, PrintStream) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter
 
DotMRPrinter.InnerOperator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
Helper class to represent the relationship of map, reduce and combine phases in an MR operator.
DotMRPrinter.InnerPlan - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
Helper class to represent the relationship of map, reduce and combine phases in an MR operator.
DotPlanDumper<E extends Operator,P extends OperatorPlan<E>,N extends Operator,S extends OperatorPlan<N>> - Class in org.apache.pig.impl.plan
This class puts everything that is needed to dump a plan in a format readable by graphviz's dot algorithm.
DotPlanDumper(P, PrintStream) - Constructor for class org.apache.pig.impl.plan.DotPlanDumper
 
DotPlanDumper(P, PrintStream, boolean, Set<Operator>, Set<Operator>, Set<Operator>) - Constructor for class org.apache.pig.impl.plan.DotPlanDumper
 
DotPlanDumper - Class in org.apache.pig.newplan
This class puts everything that is needed to dump a plan in a format readable by graphviz's dot algorithm.
DotPlanDumper(BaseOperatorPlan, PrintStream) - Constructor for class org.apache.pig.newplan.DotPlanDumper
 
DotPlanDumper(BaseOperatorPlan, PrintStream, boolean, Set<Operator>, Set<Operator>, Set<Operator>) - Constructor for class org.apache.pig.newplan.DotPlanDumper
 
DotPOPrinter - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans
This class can print a physical plan in the DOT format.
DotPOPrinter(PhysicalPlan, PrintStream) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.DotPOPrinter
 
DotPOPrinter(PhysicalPlan, PrintStream, boolean, Set<Operator>, Set<Operator>, Set<Operator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.DotPOPrinter
 
DotSparkPrinter - Class in org.apache.pig.backend.hadoop.executionengine.spark.plan
This class can print Spark plan in the DOT format.
DotSparkPrinter(SparkOperPlan, PrintStream) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter
 
DotSparkPrinter.InnerOperator - Class in org.apache.pig.backend.hadoop.executionengine.spark.plan
Helper class to represent the relationship of inner operators
DotSparkPrinter.InnerPlan - Class in org.apache.pig.backend.hadoop.executionengine.spark.plan
Each spark operator will have and an inner plan of inner operators.
doTupleWork(Tuple, AlgebraicMathBase.KnownOpProvider) - Static method in class org.apache.pig.builtin.AlgebraicBigDecimalMathBase
 
doTupleWork(Tuple, AlgebraicMathBase.KnownOpProvider) - Static method in class org.apache.pig.builtin.AlgebraicBigIntegerMathBase
 
doTupleWork(Tuple, AlgebraicMathBase.KnownOpProvider, byte) - Static method in class org.apache.pig.builtin.AlgebraicByteArrayMathBase
 
doTupleWork(Tuple, AlgebraicMathBase.KnownOpProvider) - Static method in class org.apache.pig.builtin.AlgebraicDoubleMathBase
 
doTupleWork(Tuple, AlgebraicMathBase.KnownOpProvider) - Static method in class org.apache.pig.builtin.AlgebraicFloatMathBase
 
doTupleWork(Tuple, AlgebraicMathBase.KnownOpProvider) - Static method in class org.apache.pig.builtin.AlgebraicIntMathBase
 
doTupleWork(Tuple, AlgebraicMathBase.KnownOpProvider) - Static method in class org.apache.pig.builtin.AlgebraicLongMathBase
 
DOUBLE - Static variable in class org.apache.pig.data.BinInterSedes
 
DOUBLE - Static variable in class org.apache.pig.data.DataType
 
DOUBLE_QUOTE - Static variable in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
DoubleAbs - Class in org.apache.pig.builtin
 
DoubleAbs() - Constructor for class org.apache.pig.builtin.DoubleAbs
 
DoubleAbs - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
DoubleAbs() - Constructor for class org.apache.pig.piggybank.evaluation.math.DoubleAbs
Deprecated.
 
DoubleAvg - Class in org.apache.pig.builtin
This method should never be used directly, use AVG.
DoubleAvg() - Constructor for class org.apache.pig.builtin.DoubleAvg
 
DoubleAvg.Final - Class in org.apache.pig.builtin
 
DoubleAvg.Initial - Class in org.apache.pig.builtin
 
DoubleAvg.Intermediate - Class in org.apache.pig.builtin
 
DoubleBase - Class in org.apache.pig.builtin
base class for math udfs that return Double value
DoubleBase() - Constructor for class org.apache.pig.builtin.DoubleBase
 
DoubleBase - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
DoubleBase() - Constructor for class org.apache.pig.piggybank.evaluation.math.DoubleBase
Deprecated.
 
doubleColonsToDoubleUnderscores - Variable in class org.apache.pig.builtin.AvroStorage
 
DoubleCopySign - Class in org.apache.pig.piggybank.evaluation.math
math.copySign implements a binding to the Java function Math.copySign(double,double).
DoubleCopySign() - Constructor for class org.apache.pig.piggybank.evaluation.math.DoubleCopySign
 
DoubleDoubleBase - Class in org.apache.pig.piggybank.evaluation.math
base class for math udfs that return Double value
DoubleDoubleBase() - Constructor for class org.apache.pig.piggybank.evaluation.math.DoubleDoubleBase
 
DoubleGetExponent - Class in org.apache.pig.piggybank.evaluation.math
math.getExponent implements a binding to the Java function Math.getExponent(double).
DoubleGetExponent() - Constructor for class org.apache.pig.piggybank.evaluation.math.DoubleGetExponent
 
DoubleGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.DoubleGroovyAlgebraicEvalFunc
 
DoubleJrubyAlgebraicEvalFunc(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.DoubleJrubyAlgebraicEvalFunc
 
DoubleMax - Class in org.apache.pig.builtin
This method should never be used directly, use MAX.
DoubleMax() - Constructor for class org.apache.pig.builtin.DoubleMax
 
DoubleMax - Class in org.apache.pig.piggybank.evaluation.math
math.max implements a binding to the Java function Math.max(int,int) for computing the the max value of the arguments.
DoubleMax() - Constructor for class org.apache.pig.piggybank.evaluation.math.DoubleMax
 
DoubleMax.Final - Class in org.apache.pig.builtin
 
DoubleMax.Intermediate - Class in org.apache.pig.builtin
 
DoubleMin - Class in org.apache.pig.builtin
This method should never be used directly, use MIN.
DoubleMin() - Constructor for class org.apache.pig.builtin.DoubleMin
 
DoubleMin - Class in org.apache.pig.piggybank.evaluation.math
math.min implements a binding to the Java function Math.min(int,int) for computing the the min value of the arguments.
DoubleMin() - Constructor for class org.apache.pig.piggybank.evaluation.math.DoubleMin
 
DoubleMin.Final - Class in org.apache.pig.builtin
 
DoubleMin.Intermediate - Class in org.apache.pig.builtin
 
DoubleNextAfter - Class in org.apache.pig.piggybank.evaluation.math
math.nextAfter implements a binding to the Java function Math.nextAfter(double,double).
DoubleNextAfter() - Constructor for class org.apache.pig.piggybank.evaluation.math.DoubleNextAfter
 
DoubleNextup - Class in org.apache.pig.piggybank.evaluation.math
math.NEXTUP implements a binding to the Java function Math.nextUp(double).
DoubleNextup() - Constructor for class org.apache.pig.piggybank.evaluation.math.DoubleNextup
 
DoubleRound - Class in org.apache.pig.builtin
Given a single data atom it Returns the closest long to the argument.
DoubleRound() - Constructor for class org.apache.pig.builtin.DoubleRound
 
DoubleRound - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
DoubleRound() - Constructor for class org.apache.pig.piggybank.evaluation.math.DoubleRound
Deprecated.
 
DoubleRoundTo - Class in org.apache.pig.builtin
ROUND_TO safely rounds a number to a given precision by using an intermediate BigDecimal.
DoubleRoundTo() - Constructor for class org.apache.pig.builtin.DoubleRoundTo
 
DoubleSchema - Static variable in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
 
DoubleSignum - Class in org.apache.pig.piggybank.evaluation.math
math.SIGNUM implements a binding to the Java function Math.signum(double).
DoubleSignum() - Constructor for class org.apache.pig.piggybank.evaluation.math.DoubleSignum
 
DoubleSum - Class in org.apache.pig.builtin
This method should never be used directly, use SUM.
DoubleSum() - Constructor for class org.apache.pig.builtin.DoubleSum
 
DoubleSum.Final - Class in org.apache.pig.builtin
 
DoubleSum.Intermediate - Class in org.apache.pig.builtin
 
DoubleUlp - Class in org.apache.pig.piggybank.evaluation.math
math.ULP implements a binding to the Java function Math.ulp(double).
DoubleUlp() - Constructor for class org.apache.pig.piggybank.evaluation.math.DoubleUlp
 
DoubleWritable - Class in org.apache.pig.backend.hadoop
Writable for Double values.
DoubleWritable() - Constructor for class org.apache.pig.backend.hadoop.DoubleWritable
 
DoubleWritable(double) - Constructor for class org.apache.pig.backend.hadoop.DoubleWritable
 
DoubleWritable.Comparator - Class in org.apache.pig.backend.hadoop
A Comparator optimized for DoubleWritable.
downloadArtifact(URI, PigServer) - Method in class org.apache.pig.tools.DownloadResolver
 
DownloadResolver - Class in org.apache.pig.tools
 
dropInstance() - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.TezResourceManager
This method is only used by test code to reset state.
dryrun(String, PigContext) - Static method in class org.apache.pig.Main
 
DryRunGruntParser - Class in org.apache.pig.parser
 
DryRunGruntParser(Reader, String, PigContext) - Constructor for class org.apache.pig.parser.DryRunGruntParser
 
ds - Variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
dump() - Method in class org.apache.pig.impl.plan.DotPlanDumper
 
dump(PrintStream) - Method in class org.apache.pig.impl.plan.OperatorPlan
 
dump() - Method in class org.apache.pig.impl.plan.PlanDumper
This is the public interface.
dump() - Method in class org.apache.pig.newplan.DotPlanDumper
 
dump() - Method in class org.apache.pig.newplan.PlanDumper
This is the public interface.
dumpEdge(Operator, Operator) - Method in class org.apache.pig.impl.plan.DotPlanDumper
 
dumpEdge(Operator, Operator) - Method in class org.apache.pig.impl.plan.PlanDumper
Will be called to dump the edges of the plan.
dumpEdge(Operator, Operator) - Method in class org.apache.pig.newplan.DotPlanDumper
 
dumpEdge(Operator, Operator) - Method in class org.apache.pig.newplan.PlanDumper
Will be called to dump the edges of the plan.
dumpInvisibleOperators(E) - Method in class org.apache.pig.impl.plan.DotPlanDumper
 
dumpInvisibleOperators(Operator) - Method in class org.apache.pig.newplan.DotPlanDumper
 
dumpMultiInputNestedOperator(E, MultiMap<E, S>) - Method in class org.apache.pig.impl.plan.DotPlanDumper
 
dumpMultiInputNestedOperator(E, MultiMap<E, S>) - Method in class org.apache.pig.impl.plan.PlanDumper
Will be called when an operator has nested plans, which are connected to one of the multiple inputs.
dumpMultiInputNestedOperator(Operator, MultiMap<Operator, BaseOperatorPlan>) - Method in class org.apache.pig.newplan.DotPlanDumper
 
dumpMultiInputNestedOperator(Operator, MultiMap<Operator, BaseOperatorPlan>) - Method in class org.apache.pig.newplan.PlanDumper
Will be called when an operator has nested plans, which are connected to one of the multiple inputs.
dumpMultiOutputNestedOperator(E, Collection<S>) - Method in class org.apache.pig.impl.plan.DotPlanDumper
 
dumpMultiOutputNestedOperator(E, Collection<S>) - Method in class org.apache.pig.impl.plan.PlanDumper
Will be called for nested operators, where the plans represent how the output of the operator is processed.
dumpMultiOutputNestedOperator(Operator, Collection<BaseOperatorPlan>) - Method in class org.apache.pig.newplan.DotPlanDumper
 
dumpMultiOutputNestedOperator(Operator, Collection<BaseOperatorPlan>) - Method in class org.apache.pig.newplan.PlanDumper
Will be called for nested operators, where the plans represent how the output of the operator is processed.
dumpNestedOperator(E, Collection<S>) - Method in class org.apache.pig.impl.plan.DotPlanDumper
 
dumpNestedOperator(E, Collection<S>) - Method in class org.apache.pig.impl.plan.PlanDumper
Will be called for nested operators.
dumpNestedOperator(Operator, Collection<BaseOperatorPlan>) - Method in class org.apache.pig.newplan.DotPlanDumper
 
dumpNestedOperator(Operator, Collection<BaseOperatorPlan>) - Method in class org.apache.pig.newplan.PlanDumper
Will be called for nested operators.
dumpNestedSchema(String, String) - Method in class org.apache.pig.newplan.logical.relational.LOForEach
 
dumpOperator(E) - Method in class org.apache.pig.impl.plan.DotPlanDumper
 
dumpOperator(E) - Method in class org.apache.pig.impl.plan.PlanDumper
Will be called to dump a simple operator
dumpOperator(Operator) - Method in class org.apache.pig.newplan.DotPlanDumper
 
dumpOperator(Operator) - Method in class org.apache.pig.newplan.PlanDumper
Will be called to dump a simple operator
dumpSchema(String) - Method in class org.apache.pig.PigServer
Write the schema for an alias to System.out.
dumpSchemaNested(String, String) - Method in class org.apache.pig.PigServer
Write the schema for a nestedAlias to System.out.
dumpTimers(PrintStream) - Method in class org.apache.pig.tools.timer.PerformanceTimerFactory
Call print on all of the known performance timers.
dumpTimers() - Method in class org.apache.pig.tools.timer.PerformanceTimerFactory
 
dumTup - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
duplicate() - Method in class org.apache.pig.PigServer.Graph
 
DuplicatedSchemaAliasException - Exception in org.apache.pig.parser
 
DuplicatedSchemaAliasException(IntStream, SourceLocation, String) - Constructor for exception org.apache.pig.parser.DuplicatedSchemaAliasException
 
DuplicateForEachColumnRewriteVisitor - Class in org.apache.pig.newplan.logical.visitor
 
DuplicateForEachColumnRewriteVisitor(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.DuplicateForEachColumnRewriteVisitor
 
dupNode() - Method in class org.apache.pig.parser.PigParserNode
 

E

each(ThreadContext, Block) - Method in class org.apache.pig.scripting.jruby.RubyDataBag
This is an implementation of the each method which opens up the Enumerable interface, and makes it very convenient to iterate over the elements of a DataBag.
earlyTermination - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
ElementDescriptor - Interface in org.apache.pig.backend.datastorage
DataStorageElementDescriptor provides methods necessary to manage an element in a DataStorage.
emitInitialPlanNotification(OperatorPlan<?>) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
emitJobFailedNotification(JobStats) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
emitjobFinishedNotification(JobStats) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
emitJobsSubmittedNotification(int) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
emitJobStartedNotification(String) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
emitLaunchCompletedNotification(int) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
emitLaunchStartedNotification(int) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
emitOutputCompletedNotification(OutputStats) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
emitProgressUpdatedNotification(int) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
EMPTY_KEY - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
EMPTY_STRING - Static variable in class org.apache.pig.piggybank.evaluation.xml.XPathAll
 
EmptyPigStats - Class in org.apache.pig.tools.pigstats
EmptyPigStats encapsulates dummy statistics of a fetch task, since during a fetch no MR jobs are executed
EmptyPigStats() - Constructor for class org.apache.pig.tools.pigstats.EmptyPigStats
 
EmptyPigStats(PigContext, POStore) - Constructor for class org.apache.pig.tools.pigstats.EmptyPigStats
 
EmptyWritable() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez.EmptyWritable
 
ENABLE_ATS - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
use PigConfiguration.PIG_ATS_ENABLED instead. Will be removed in Pig 0.18
encodeBytes(byte[]) - Static method in class org.apache.pig.impl.util.ObjectSerializer
 
end - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
end - Variable in class org.apache.pig.builtin.BinStorage
 
END_OF_INP_IN_MAP - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
END_OF_OUTPUT - Static variable in class org.apache.pig.impl.streaming.OutputHandler
 
END_ROW_OPTION - Static variable in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
endBag - Static variable in class org.apache.pig.data.DefaultAbstractBag
 
EndBag() - Constructor for class org.apache.pig.data.DefaultAbstractBag.EndBag
 
endOfAllInput - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
EndOfAllInputChecker(PhysicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter.EndOfAllInputChecker
 
endOfAllInputProcessed - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
endOfAllInputProcessing - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
EndOfAllInputSetter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
This visitor visits the MRPlan and does the following for each MROper: If the map plan or the reduce plan of the MROper has an end of all input flag present in it, this marks in the MROper whether the map has an end of all input flag set or if the reduce has an end of all input flag set.
EndOfAllInputSetter(MROperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter
 
EndOfAllInputSetter.EndOfAllInputChecker - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
 
EndOfOpts - Static variable in class org.apache.pig.tools.cmdline.CmdLineParser
 
ENDSWITH - Class in org.apache.pig.builtin
Pig UDF to test input tuple.get(0) against tuple.get(1) to determine if the first argument ends with the string in the second.
ENDSWITH() - Constructor for class org.apache.pig.builtin.ENDSWITH
 
endTime - Variable in class org.apache.pig.tools.pigstats.PigStats
 
ensureAllKeyInstancesInSameSplit() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
ensureAllKeyInstancesInSameSplit() - Method in interface org.apache.pig.CollectableLoadFunc
When this method is called, Pig is communicating to the Loader that it must load data such that all instances of a key are in same split.
ENTITY_CALLERID - Static variable in class org.apache.pig.backend.hadoop.PigATSClient
 
ENTITY_TYPE - Static variable in class org.apache.pig.backend.hadoop.PigATSClient
 
entrySet() - Method in class org.apache.pig.impl.util.avro.AvroMapWrapper
 
enumeratorize(Ruby, IRubyObject, String) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
This is a hack to get around the fact that in JRuby 1.6.7, the enumeratorize method isn't public.
equalByteArrays(byte[], byte[]) - Static method in class org.apache.pig.data.DataType
Test whether two byte arrays (Java byte arrays not Pig byte arrays) are equal.
EqualExpression - Class in org.apache.pig.newplan.logical.expression
Equality test expression.
EqualExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.EqualExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
equals(Object) - Method in class org.apache.pig.backend.hadoop.accumulo.Column
 
equals(Object) - Method in class org.apache.pig.backend.hadoop.BigDecimalWritable
 
equals(Object) - Method in class org.apache.pig.backend.hadoop.BigIntegerWritable
 
equals(Object) - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
equals(Object) - Method in class org.apache.pig.backend.hadoop.DateTimeWritable
Returns true iff o is a DateTimeWritable with the same value.
equals(Object) - Method in class org.apache.pig.backend.hadoop.DoubleWritable
Returns true iff o is a DoubleWritable with the same value.
equals(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnChainInfo
 
equals(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnInfo
 
equals(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.IndexedKey
If key is empty, we'd like compute equality based on key and index.
equals(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerNode
 
equals(Object) - Method in class org.apache.pig.backend.hadoop.hbase.TableSplitComparable
 
equals(Object) - Method in class org.apache.pig.builtin.PigStorage
 
equals(PigStorage) - Method in class org.apache.pig.builtin.PigStorage
 
equals(Object) - Method in class org.apache.pig.data.AbstractTuple
 
equals(Object) - Method in class org.apache.pig.data.AccumulativeBag
 
equals(Object) - Method in class org.apache.pig.data.DataByteArray
 
equals(Object) - Method in class org.apache.pig.data.DefaultAbstractBag
 
equals(Object) - Method in class org.apache.pig.data.NonSpillableDataBag
 
equals(Object) - Method in class org.apache.pig.data.ReadOnceBag
 
equals(Object) - Method in class org.apache.pig.data.SchemaTuple
 
equals(Object) - Method in class org.apache.pig.data.SingleTupleBag
 
equals(Object) - Method in class org.apache.pig.data.TargetedTuple
 
equals(Object) - Method in class org.apache.pig.data.utils.StructuresHelper.Pair
 
equals(Object) - Method in class org.apache.pig.data.utils.StructuresHelper.SchemaKey
 
equals(Object) - Method in class org.apache.pig.data.utils.StructuresHelper.Triple
 
equals(Object) - Method in class org.apache.pig.FileSplitComparable
 
equals(Object) - Method in class org.apache.pig.FuncSpec
 
equals(Object) - Method in class org.apache.pig.impl.io.FileSpec
 
equals(Object) - Method in class org.apache.pig.impl.io.PigNullableWritable
 
equals(Object) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
For two schemas to be equal, they have to be deeply equal.
equals(Schema, Schema, boolean, boolean) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
Recursively compare two schemas for equality
equals(Object) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Two field schemas are equal if types and schemas are equal in all levels.
equals(Schema.FieldSchema, Schema.FieldSchema, boolean, boolean) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Compare two field schema for equality
equals(Object) - Method in class org.apache.pig.impl.plan.Operator
Compares to Operators based on their opKey
equals(Object) - Method in class org.apache.pig.impl.plan.OperatorKey
 
equals(Object) - Method in class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
 
equals(Object) - Method in class org.apache.pig.impl.util.Pair
 
equals(LogicalSchema, LogicalSchema, boolean, boolean) - Static method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Recursively compare two schemas for equality
equals(LogicalSchema.LogicalFieldSchema, LogicalSchema.LogicalFieldSchema, boolean, boolean) - Static method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
Compare two field schema for equality
equals(Object) - Method in class org.apache.pig.piggybank.storage.XMLLoader.XMLRecordReader
 
equals(ResourceSchema, ResourceSchema) - Static method in class org.apache.pig.ResourceSchema
Test whether two ResourceSchemas are the same.
equals(Object) - Method in class org.apache.pig.ResourceStatistics
 
equals(Object) - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
equals(ThreadContext, IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubyDataByteArray
Overrides equality leveraging DataByteArray's equality.
equals(Object) - Method in class org.apache.pig.SortColInfo
 
equals(Object) - Method in class org.apache.pig.SortInfo
 
EqualsIgnoreCase - Class in org.apache.pig.builtin
Compares two Strings ignoring case considerations.
EqualsIgnoreCase() - Constructor for class org.apache.pig.builtin.EqualsIgnoreCase
 
equalsZero(Number, byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
EqualToExpr - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
EqualToExpr(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.EqualToExpr
 
EqualToExpr(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.EqualToExpr
 
EquivalenceClasses - Class in org.apache.pig.pen
 
EquivalenceClasses() - Constructor for class org.apache.pig.pen.EquivalenceClasses
 
ERR_MSG_SCALAR - Static variable in class org.apache.pig.newplan.logical.visitor.ScalarVariableValidator
 
ERROR - Static variable in class org.apache.pig.data.DataType
 
ERROR - Static variable in exception org.apache.pig.PigException
 
ErrorCallback() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.MonitoredUDFExecutor.ErrorCallback
 
errorCode - Variable in exception org.apache.pig.PigException
 
errorCode - Variable in class org.apache.pig.tools.pigstats.PigStats
 
ErrorHandler - Interface in org.apache.pig
The interface that handles errors thrown by the StoreFuncInterface.putNext(Tuple)
ErrorHandling - Interface in org.apache.pig
A StoreFunc should implement this interface to enable handling errors during StoreFunc#putNext(Tuple)
errorInMap - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
 
errorInReduce - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
 
errorMessage - Variable in class org.apache.pig.tools.pigstats.PigStats
 
errorSource - Variable in exception org.apache.pig.PigException
 
errorThrowable - Variable in class org.apache.pig.tools.pigstats.PigStats
 
ESTIMATE_PARALLELISM - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
ESTIMATED_NUM_PARALLELISM - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
estimateNumberOfReducers(Job, MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.InputSizeReducerEstimator
Determines the number of reducers to be used.
estimateNumberOfReducers(Job, MapReduceOper) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
Looks up the estimator from REDUCER_ESTIMATOR_KEY and invokes it to find the number of reducers to use.
estimateNumberOfReducers(Job, MapReduceOper) - Method in interface org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigReducerEstimator
Estimate the number of reducers for a given job based on the collection of load funcs passed.
estimateParallelism(TezOperPlan, TezOperator, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezOperDependencyParallelismEstimator
 
estimateParallelism(TezOperPlan, TezOperator, Configuration) - Method in interface org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezParallelismEstimator
 
eval(Tuple) - Method in interface org.apache.pig.builtin.InvokerFunction
 
eval(String) - Method in class org.apache.pig.scripting.js.JsScriptEngine
 
EvalFunc<T> - Class in org.apache.pig
The class is used to implement functions to be applied to fields in a dataset.
EvalFunc() - Constructor for class org.apache.pig.EvalFunc
 
EvalFunc.SchemaType - Enum in org.apache.pig
EvalFunc's schema type.
ExampleGenerator - Class in org.apache.pig.pen
This class is used to generate example tuples for the ILLUSTRATE purpose
ExampleGenerator(LogicalPlan, PigContext) - Constructor for class org.apache.pig.pen.ExampleGenerator
 
ExampleTuple - Class in org.apache.pig.pen.util
 
ExampleTuple() - Constructor for class org.apache.pig.pen.util.ExampleTuple
 
ExampleTuple(Object) - Constructor for class org.apache.pig.pen.util.ExampleTuple
 
ExampleTuple(Tuple) - Constructor for class org.apache.pig.pen.util.ExampleTuple
 
ExceptionalFunction<S,T,E extends Exception> - Interface in org.apache.pig
An interface that captures a unit of work against an item where an exception might be thrown.
exec(Tuple) - Method in class org.apache.pig.AccumulatorEvalFunc
 
exec(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.FindQuantilesTez
 
exec(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.PartitionSkewedKeysTez
 
exec(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.ReadScalarsTez
 
exec() - Method in class org.apache.pig.backend.hadoop.streaming.HadoopExecutableManager
 
exec(Tuple) - Method in class org.apache.pig.builtin.ABS
java level API
exec(Tuple) - Method in class org.apache.pig.builtin.AddDuration
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicBigDecimalMathBase
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicBigDecimalMathBase.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicBigDecimalMathBase.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicBigIntegerMathBase
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicBigIntegerMathBase.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicBigIntegerMathBase.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicByteArrayMathBase
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicByteArrayMathBase.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicByteArrayMathBase.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicByteArrayMathBase.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicDoubleMathBase
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicDoubleMathBase.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicDoubleMathBase.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicFloatMathBase
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicFloatMathBase.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicFloatMathBase.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicIntMathBase
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicIntMathBase.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicIntMathBase.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicLongMathBase
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicLongMathBase.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.AlgebraicLongMathBase.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.ARITY
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.builtin.Assert
 
exec(Tuple) - Method in class org.apache.pig.builtin.AVG
 
exec(Tuple) - Method in class org.apache.pig.builtin.AVG.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.AVG.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.AVG.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.BagSize
 
exec(Tuple) - Method in class org.apache.pig.builtin.BagToString
 
exec(Tuple) - Method in class org.apache.pig.builtin.BagToTuple
 
exec(Tuple) - Method in class org.apache.pig.builtin.BigDecimalAbs
 
exec(Tuple) - Method in class org.apache.pig.builtin.BigDecimalAvg
 
exec(Tuple) - Method in class org.apache.pig.builtin.BigDecimalAvg.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.BigDecimalAvg.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.BigDecimalAvg.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.BigIntegerAbs
 
exec(Tuple) - Method in class org.apache.pig.builtin.BigIntegerAvg
 
exec(Tuple) - Method in class org.apache.pig.builtin.BigIntegerAvg.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.BigIntegerAvg.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.BigIntegerAvg.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.Bloom
 
exec(Tuple) - Method in class org.apache.pig.builtin.BuildBloom
 
exec(Tuple) - Method in class org.apache.pig.builtin.BuildBloom.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.BuildBloom.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.BuildBloom.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.CONCAT
 
exec(Tuple) - Method in class org.apache.pig.builtin.ConstantSize
 
exec(Tuple) - Method in class org.apache.pig.builtin.COR
Function to compute correlation between data sets.
exec(Tuple) - Method in class org.apache.pig.builtin.COR.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.COR.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.COR.Intermed
 
exec(Tuple) - Method in class org.apache.pig.builtin.COUNT
 
exec(Tuple) - Method in class org.apache.pig.builtin.COUNT.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.COUNT.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.COUNT.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.COUNT_STAR
 
exec(Tuple) - Method in class org.apache.pig.builtin.COUNT_STAR.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.COUNT_STAR.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.COUNT_STAR.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.COV
Function to compute covariance between data sets.
exec(Tuple) - Method in class org.apache.pig.builtin.COV.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.COV.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.COV.Intermed
 
exec(Tuple) - Method in class org.apache.pig.builtin.CubeDimensions
 
exec(Tuple) - Method in class org.apache.pig.builtin.CurrentTime
 
exec(Tuple) - Method in class org.apache.pig.builtin.DateTimeMax
 
exec(Tuple) - Method in class org.apache.pig.builtin.DateTimeMax.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.DateTimeMax.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.DateTimeMax.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.DateTimeMin
 
exec(Tuple) - Method in class org.apache.pig.builtin.DateTimeMin.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.DateTimeMin.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.DateTimeMin.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.DaysBetween
 
exec(Tuple) - Method in class org.apache.pig.builtin.DIFF
Compares a tuple with two fields.
exec(Tuple) - Method in class org.apache.pig.builtin.Distinct
 
exec(Tuple) - Method in class org.apache.pig.builtin.Distinct.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.Distinct.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.Distinct.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleAvg
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleAvg.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleAvg.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleAvg.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleBase
java level API
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleRound
java level API
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleRoundTo
java level API
exec(Tuple) - Method in class org.apache.pig.builtin.ENDSWITH
 
exec(Tuple) - Method in class org.apache.pig.builtin.EqualsIgnoreCase
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatAbs
java level API
exec(Tuple) - Method in class org.apache.pig.builtin.FloatAvg
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatAvg.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatAvg.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatAvg.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatRound
java level API
exec(Tuple) - Method in class org.apache.pig.builtin.FloatRoundTo
java level API
exec(Object) - Method in class org.apache.pig.builtin.FunctionWrapperEvalFunc
 
exec(Tuple) - Method in class org.apache.pig.builtin.GenericInvoker
 
exec(Tuple) - Method in class org.apache.pig.builtin.GetDay
 
exec(Tuple) - Method in class org.apache.pig.builtin.GetHour
 
exec(Tuple) - Method in class org.apache.pig.builtin.GetMilliSecond
 
exec(Tuple) - Method in class org.apache.pig.builtin.GetMinute
 
exec(Tuple) - Method in class org.apache.pig.builtin.GetMonth
 
exec(Tuple) - Method in class org.apache.pig.builtin.GetSecond
 
exec(Tuple) - Method in class org.apache.pig.builtin.GetWeek
 
exec(Tuple) - Method in class org.apache.pig.builtin.GetWeekYear
 
exec(Tuple) - Method in class org.apache.pig.builtin.GetYear
 
exec(Tuple) - Method in class org.apache.pig.builtin.HiveUDAF
 
exec(Tuple) - Method in class org.apache.pig.builtin.HiveUDAF.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.HiveUDAF.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.HiveUDAF.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.HiveUDF
 
exec(Tuple) - Method in class org.apache.pig.builtin.HiveUDTF
 
exec(Tuple) - Method in class org.apache.pig.builtin.HoursBetween
 
exec(Tuple) - Method in class org.apache.pig.builtin.INDEXOF
Method invoked on every tuple during foreach evaluation
exec(Tuple) - Method in class org.apache.pig.builtin.IntAbs
java level API
exec(Tuple) - Method in class org.apache.pig.builtin.IntAvg
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntAvg.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntAvg.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntAvg.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.INVERSEMAP
 
exec(Tuple) - Method in class org.apache.pig.builtin.InvokerGenerator
 
exec(Tuple) - Method in class org.apache.pig.builtin.IsEmpty
 
exec(Tuple) - Method in class org.apache.pig.builtin.KEYSET
 
exec(Tuple) - Method in class org.apache.pig.builtin.LAST_INDEX_OF
Finds the last location of a substring in a given string.
exec(Tuple) - Method in class org.apache.pig.builtin.LCFIRST
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongAbs
java level API
exec(Tuple) - Method in class org.apache.pig.builtin.LongAvg
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongAvg.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongAvg.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongAvg.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.LOWER
Method invoked on every tuple during foreach evaluation
exec(Tuple) - Method in class org.apache.pig.builtin.LTRIM
 
exec(Tuple) - Method in class org.apache.pig.builtin.MapSize
 
exec(Tuple) - Method in class org.apache.pig.builtin.MilliSecondsBetween
 
exec(Tuple) - Method in class org.apache.pig.builtin.MinutesBetween
 
exec(Tuple) - Method in class org.apache.pig.builtin.MonthsBetween
 
exec(Tuple) - Method in class org.apache.pig.builtin.PluckTuple
 
exec(Tuple) - Method in class org.apache.pig.builtin.RANDOM
 
exec(Tuple) - Method in class org.apache.pig.builtin.REGEX_EXTRACT
 
exec(Tuple) - Method in class org.apache.pig.builtin.REGEX_EXTRACT_ALL
 
exec(Tuple) - Method in class org.apache.pig.builtin.REGEX_SEARCH
 
exec(Tuple) - Method in class org.apache.pig.builtin.REPLACE
Method invoked on every tuple during foreach evaluation
exec(Tuple) - Method in class org.apache.pig.builtin.RollupDimensions
 
exec(Tuple) - Method in class org.apache.pig.builtin.ROUND
java level API
exec(Tuple) - Method in class org.apache.pig.builtin.ROUND_TO
java level API
exec(Tuple) - Method in class org.apache.pig.builtin.RTRIM
 
exec(Tuple) - Method in class org.apache.pig.builtin.SecondsBetween
 
exec(Tuple) - Method in class org.apache.pig.builtin.SIZE
 
exec(Tuple) - Method in class org.apache.pig.builtin.SPRINTF
 
exec(Tuple) - Method in class org.apache.pig.builtin.STARTSWITH
 
exec(Tuple) - Method in class org.apache.pig.builtin.StringConcat
 
exec(Tuple) - Method in class org.apache.pig.builtin.StringMax
 
exec(Tuple) - Method in class org.apache.pig.builtin.StringMax.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.StringMax.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.StringMax.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.StringMin
 
exec(Tuple) - Method in class org.apache.pig.builtin.StringMin.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.StringMin.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.StringMin.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.StringSize
 
exec(Tuple) - Method in class org.apache.pig.builtin.STRSPLIT
Wrapper around Java's String.split
exec(Tuple) - Method in class org.apache.pig.builtin.STRSPLITTOBAG
Wrapper around Java's String.split
exec(Tuple) - Method in class org.apache.pig.builtin.SUBSTRING
Method invoked on every tuple during foreach evaluation
exec(Tuple) - Method in class org.apache.pig.builtin.SUBTRACT
Compares the two bag fields from input Tuple and returns a new bag composed of elements of first bag not in the second bag.
exec(Tuple) - Method in class org.apache.pig.builtin.SubtractDuration
 
exec(Tuple) - Method in class org.apache.pig.builtin.TOBAG
 
exec(Tuple) - Method in class org.apache.pig.builtin.ToDate
 
exec(Tuple) - Method in class org.apache.pig.builtin.ToDate2ARGS
 
exec(Tuple) - Method in class org.apache.pig.builtin.ToDate3ARGS
 
exec(Tuple) - Method in class org.apache.pig.builtin.ToDateISO
 
exec(Tuple) - Method in class org.apache.pig.builtin.TOKENIZE
 
exec(Tuple) - Method in class org.apache.pig.builtin.TOMAP
 
exec(Tuple) - Method in class org.apache.pig.builtin.ToMilliSeconds
 
exec(Tuple) - Method in class org.apache.pig.builtin.TOP.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.TOP.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.TOP.Intermed
 
exec(Tuple) - Method in class org.apache.pig.builtin.ToString
 
exec(Tuple) - Method in class org.apache.pig.builtin.TOTUPLE
 
exec(Tuple) - Method in class org.apache.pig.builtin.ToUnixTime
 
exec(Tuple) - Method in class org.apache.pig.builtin.TRIM
 
exec(Tuple) - Method in class org.apache.pig.builtin.TupleSize
 
exec(Tuple) - Method in class org.apache.pig.builtin.UCFIRST
 
exec(Tuple) - Method in class org.apache.pig.builtin.UniqueID
 
exec(Tuple) - Method in class org.apache.pig.builtin.UPPER
Upper-cases an input string.
exec(Tuple) - Method in class org.apache.pig.builtin.VALUELIST
 
exec(Tuple) - Method in class org.apache.pig.builtin.VALUESET
 
exec(Tuple) - Method in class org.apache.pig.builtin.WeeksBetween
 
exec(Tuple) - Method in class org.apache.pig.builtin.YearsBetween
 
exec(Tuple) - Method in class org.apache.pig.EvalFunc
This callback method must be implemented by all subclasses.
exec(Tuple) - Method in class org.apache.pig.impl.builtin.FindQuantiles
first field in the input tuple is the number of quantiles to generate second field is the *sorted* bag of samples
exec(Tuple) - Method in class org.apache.pig.impl.builtin.GetMemNumRows
 
exec(Tuple) - Method in class org.apache.pig.impl.builtin.GFAny
 
exec(Tuple) - Method in class org.apache.pig.impl.builtin.GFCross
 
exec(Tuple) - Method in class org.apache.pig.impl.builtin.GFReplicate
 
exec(Tuple) - Method in class org.apache.pig.impl.builtin.IdentityColumn
 
exec(Tuple) - Method in class org.apache.pig.impl.builtin.IsFirstReduceOfKey
 
exec(Tuple) - Method in class org.apache.pig.impl.builtin.PartitionSkewedKeys
first field in the input tuple is the number of reducers second field is the *sorted* bag of samples this should be called only once
exec(Tuple) - Method in class org.apache.pig.impl.builtin.ReadScalars
Java level API
exec(Tuple) - Method in class org.apache.pig.impl.builtin.StreamingUDF
 
exec() - Method in class org.apache.pig.impl.streaming.ExecutableManager
Start execution of the external process.
exec(Iterator<Tuple>) - Method in class org.apache.pig.IteratingAccumulatorEvalFunc
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.convert.CustomFormatToISO
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.convert.ISOToUnix
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.convert.UnixToISO
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISODaysBetween
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOHoursBetween
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOMinutesBetween
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOMonthsBetween
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOSecondsBetween
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOYearsBetween
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.DiffDate
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToDay
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToHour
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToMinute
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToMonth
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToSecond
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToWeek
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToYear
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.decode.Bin
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.decode.BinCond
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.decode.Decode
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
The EvalFunc interface
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField.HelperClass
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.IsDouble
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.IsFloat
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.IsInt
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.IsLong
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.IsNumeric
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.ABS
Deprecated.
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.copySign
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleAbs
Deprecated.
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleBase
Deprecated.
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleCopySign
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleDoubleBase
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleGetExponent
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleMax
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleMin
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleNextAfter
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleNextup
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleRound
Deprecated.
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleSignum
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleUlp
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.FloatAbs
Deprecated.
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.FloatCopySign
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.FloatGetExponent
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.FloatMax
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.FloatMin
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.FloatNextAfter
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.FloatNextup
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.FloatRound
Deprecated.
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.FloatSignum
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.FloatUlp
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.getExponent
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.IntAbs
Deprecated.
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.IntMax
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.IntMin
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.LongAbs
Deprecated.
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.LongMax
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.LongMin
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.MAX
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.MIN
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.nextAfter
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.NEXTUP
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.ROUND
Deprecated.
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.SCALB
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.SIGNUM
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.math.ULP
java level API
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField.Final
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField.Initial
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.Over
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.stats.COR
Deprecated.
Function to compute correlation between data sets.
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.stats.COR.Final
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.stats.COR.Initial
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.stats.COR.Intermed
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.stats.COV
Deprecated.
Function to compute covariance between data sets.
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.stats.COV.Final
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.stats.COV.Initial
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.stats.COV.Intermed
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.Stitch
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.HashFNV
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.HashFNV1
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.HashFNV2
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.LENGTH
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.LookupInFiles
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.RegexExtract
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.RegexExtractAll
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.RegexMatch
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.REPLACE_MULTI
Method invoked on every tuple during FOREACH evaluation.
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.Reverse
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.Stuff
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.UPPER
Deprecated.
Upper-cases an input string.
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.util.apachelogparser.DateExtractor
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.util.apachelogparser.HostExtractor
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.util.apachelogparser.SearchEngineExtractor
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.util.apachelogparser.SearchTermExtractor
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.util.SearchQuery
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.util.ToBag
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.util.Top
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.util.Top.Final
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.util.Top.Initial
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.util.Top.Intermed
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.util.ToTuple
Deprecated.
 
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.xml.XPath
input should contain: 1) xml 2) xpath 3) optional cache xml doc flag 4) optional ignore namespace flag Usage: 1) XPath(xml, xpath) 2) XPath(xml, xpath, false) 3) XPath(xml, xpath, false, false)
exec(Tuple) - Method in class org.apache.pig.piggybank.evaluation.xml.XPathAll
input should contain: 1) xml 2) xpath 3) optional cache xml doc flag 4) optional ignore namespace flag The optional fourth parameter (IGNORE_NAMESPACE), if set true will remove the namespace from xPath For example xpath /html:body/html:div will be considered as /body/div Usage: 1) XPathAll(xml, xpath) 2) XPathAll(xml, xpath, false) 3) XPathAll(xml, xpath, false, false)
exec(Tuple) - Method in class org.apache.pig.PrimitiveEvalFunc
 
exec(IN) - Method in class org.apache.pig.PrimitiveEvalFunc
 
exec(Tuple) - Method in class org.apache.pig.scripting.groovy.GroovyEvalFunc
 
exec(Tuple) - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
exec(Tuple) - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.Final
 
exec(Tuple) - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.Initial
 
exec(Tuple) - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.Intermed
 
exec(Tuple) - Method in class org.apache.pig.scripting.jruby.JrubyEvalFunc
The exec method passes the tuple argument to the Ruby function, and converts the result back to Pig.
exec(Tuple) - Method in class org.apache.pig.scripting.js.JsFunction
 
exec(Tuple) - Method in class org.apache.pig.scripting.jython.JythonFunction
 
exec() - Method in class org.apache.pig.tools.grunt.Grunt
 
ExecException - Exception in org.apache.pig.backend.executionengine
 
ExecException() - Constructor for exception org.apache.pig.backend.executionengine.ExecException
Create a new ExecException with null as the error message.
ExecException(String) - Constructor for exception org.apache.pig.backend.executionengine.ExecException
Create a new ExecException with the specified message and cause.
ExecException(Throwable) - Constructor for exception org.apache.pig.backend.executionengine.ExecException
Create a new ExecException with the specified cause.
ExecException(String, Throwable) - Constructor for exception org.apache.pig.backend.executionengine.ExecException
Create a new ExecException with the specified message and cause.
ExecException(String, int) - Constructor for exception org.apache.pig.backend.executionengine.ExecException
Create a new ExecException with the specified message and cause.
ExecException(String, int, Throwable) - Constructor for exception org.apache.pig.backend.executionengine.ExecException
Create a new ExecException with the specified message and cause.
ExecException(String, int, byte) - Constructor for exception org.apache.pig.backend.executionengine.ExecException
Create a new ExecException with the specified message and cause.
ExecException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.backend.executionengine.ExecException
Create a new ExecException with the specified message and cause.
ExecException(String, int, boolean) - Constructor for exception org.apache.pig.backend.executionengine.ExecException
Create a new ExecException with the specified message and cause.
ExecException(String, int, byte, boolean) - Constructor for exception org.apache.pig.backend.executionengine.ExecException
Create a new ExecException with the specified message and cause.
ExecException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.backend.executionengine.ExecException
Create a new ExecException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
ExecException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.backend.executionengine.ExecException
Create a new ExecException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
ExecJob - Interface in org.apache.pig.backend.executionengine
Abstraction on a job that the execution engine runs.
ExecJob.JOB_STATUS - Enum in org.apache.pig.backend.executionengine
 
ExecType - Interface in org.apache.pig
The type of query execution.
ExecTypeProvider - Class in org.apache.pig
 
ExecTypeProvider() - Constructor for class org.apache.pig.ExecTypeProvider
 
ExecutableManager - Class in org.apache.pig.impl.streaming
ExecutableManager manages an external executable which processes data in a Pig query.
ExecutableManager() - Constructor for class org.apache.pig.impl.streaming.ExecutableManager
Create a new ExecutableManager.
execute(LogicalExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
Method to call on every node in the logical expression plan.
execute(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
Method to call on every node in the logical plan.
execute(LogicalExpression) - Method in class org.apache.pig.newplan.logical.rules.ConstantCalculator.ConstantCalculatorTransformer.ConstantCalculatorExpressionVisitor
 
execute(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.visitor.ImplicitSplitInsertVisitor
 
execute(String) - Method in class org.apache.pig.tools.grunt.Command
 
executeBatch() - Method in class org.apache.pig.PigServer
Submits a batch of Pig commands for execution.
executeBatch(boolean) - Method in class org.apache.pig.PigServer
Submits a batch of Pig commands for execution.
ExecutionEngine - Interface in org.apache.pig.backend.executionengine
The main interface bridging the front end and back end of Pig.
exists() - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
Checks whether the entity exists or not
exists() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
existsFile(String) - Method in class org.apache.pig.PigServer
Test whether a file exists.
exitCode - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
EXP - Class in org.apache.pig.builtin
Given a single data atom it returns the Euler's number e raised to the power of input
EXP() - Constructor for class org.apache.pig.builtin.EXP
 
EXP - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use EXP
EXP() - Constructor for class org.apache.pig.piggybank.evaluation.math.EXP
Deprecated.
 
expandForAlternativeNames(String, String) - Static method in class org.apache.pig.backend.hadoop.datastorage.ConfigurationUtil
Returns Properties containing alternative names of given property and same values - can be used to solve deprecations
explain(LogicalPlan, PigContext, PrintStream, String, boolean, File, String) - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
This method handles the backend processing of the Explain command.
explain(PhysicalPlan, PigContext, PrintStream, String) - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchLauncher
Creates an empty MR plan
explain(LogicalPlan, PigContext, PrintStream, String, boolean, File, String) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
explain(PhysicalPlan, PigContext, PrintStream, String, boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
Explain how a pig job will be executed on the underlying infrastructure.
explain(PhysicalPlan, PigContext, PrintStream, String, boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceLauncher
 
explain(OutputStream) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
Write a visual representation of the Physical Plan into the given output stream
explain(OutputStream, boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
Write a visual representation of the Physical Plan into the given output stream
explain(PrintStream, String, boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
Write a visual representation of the Physical Plan into the given printstream
explain(PhysicalPlan, PigContext, PrintStream, String, boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkLauncher
 
explain(PhysicalPlan, PigContext, PrintStream, String, boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezLauncher
 
explain(PrintStream, String, boolean) - Method in class org.apache.pig.newplan.BaseOperatorPlan
 
explain(PrintStream, String, boolean) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionPlan
 
explain(PrintStream, String, boolean) - Method in class org.apache.pig.newplan.logical.relational.LogicalPlan
 
explain(String, PrintStream) - Method in class org.apache.pig.PigServer
Provide information on how a pig query will be executed.
explain(String, String, boolean, boolean, PrintStream, PrintStream, File, String) - Method in class org.apache.pig.PigServer
Provide information on how a pig query will be executed.
explain() - Method in class org.apache.pig.scripting.BoundScript
Explain this pipeline.
explainCurrentBatch() - Method in class org.apache.pig.tools.grunt.GruntParser
 
explainCurrentBatch(boolean) - Method in class org.apache.pig.tools.grunt.GruntParser
 
ExplainState(String, String, String, boolean, String) - Constructor for class org.apache.pig.tools.grunt.GruntParser.ExplainState
 
EXPM1 - Class in org.apache.pig.piggybank.evaluation.math
math.EXPM1 implements a binding to the Java function Math.expm1(double).
EXPM1() - Constructor for class org.apache.pig.piggybank.evaluation.math.EXPM1
 
Expression - Class in org.apache.pig
A class to communicate Filter expressions to LoadFuncs.
Expression() - Constructor for class org.apache.pig.Expression
 
Expression.BetweenExpression - Class in org.apache.pig
 
Expression.BinaryExpression - Class in org.apache.pig
 
Expression.Column - Class in org.apache.pig
 
Expression.Const - Class in org.apache.pig
 
Expression.InExpression - Class in org.apache.pig
 
Expression.OpType - Enum in org.apache.pig
 
Expression.UnaryExpression - Class in org.apache.pig
 
ExpressionOperator - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
A base class for all types of expressions.
ExpressionOperator(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
 
ExpressionOperator(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
 
ExpToPhyTranslationVisitor - Class in org.apache.pig.newplan.logical.expression
 
ExpToPhyTranslationVisitor(OperatorPlan, LogicalRelationalOperator, PhysicalPlan, Map<Operator, PhysicalOperator>) - Constructor for class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
ExpToPhyTranslationVisitor(OperatorPlan, PlanWalker, LogicalRelationalOperator, PhysicalPlan, Map<Operator, PhysicalOperator>) - Constructor for class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
EXT - Static variable in class org.apache.pig.piggybank.storage.avro.PigAvroOutputFormat
The file name extension for avro data files.
EXTENSION_OVERRIDE_CONF - Static variable in class org.apache.pig.piggybank.storage.hiverc.HiveRCOutputFormat
 
extractArgs(CommandLine, AccumuloStorageOptions) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
Extract arguments passed into the constructor to avoid the URI
extractDateTime(String) - Static method in class org.apache.pig.builtin.ToDate
 
extractDateTimeZone(String) - Static method in class org.apache.pig.builtin.ToDate
 
extractDayDate(String) - Static method in class org.apache.pig.piggybank.storage.hiverc.HiveRCSchemaUtil
Extract the date from the hive file names e.g /user/hive/warehouse/table/daydate=2009-10-01/upload001/0002.dat
This method will extract the 2009-10-01 from this name.
extractHeapSizeInMB(String) - Static method in class org.apache.pig.impl.util.Utils
 
extractPigTypeFromHiveType(Object) - Static method in class org.apache.pig.piggybank.storage.hiverc.HiveRCSchemaUtil
Converts from a hive type to a pig type
extraJars - Variable in class org.apache.pig.impl.PigContext
 
ExtremalTupleByNthField - Class in org.apache.pig.piggybank.evaluation
This class is similar to MaxTupleBy1stField except that it allows you to specify with field to use (instead of just using 1st field) and to specify ascending or descending.
ExtremalTupleByNthField() - Constructor for class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
Constructors
ExtremalTupleByNthField(String) - Constructor for class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
 
ExtremalTupleByNthField(String, String) - Constructor for class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
 
ExtremalTupleByNthField.HelperClass - Class in org.apache.pig.piggybank.evaluation
Utility classes and methods
extreme(int, int, Tuple, PigProgressable) - Static method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
 

F

FAILURE - Static variable in class org.apache.pig.PigRunner.ReturnCode
 
FAILURE_HEADER - Static variable in class org.apache.pig.tools.pigstats.JobStats
 
FAILURE_HEADER - Static variable in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
FAILURE_HEADER - Static variable in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
failureMap - Variable in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
FakeRawKeyValueIterator - Class in org.apache.pig.pen
 
FakeRawKeyValueIterator(boolean) - Constructor for class org.apache.pig.pen.FakeRawKeyValueIterator
 
fe - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
FEATURE - Static variable in class org.apache.pig.tools.pigstats.JobStats
 
featureLongToString(long) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
FeatureVisitor(PhysicalPlan, BitSet) - Constructor for class org.apache.pig.tools.pigstats.ScriptState.FeatureVisitor
 
FetchContext - Class in org.apache.pig.backend.hadoop.executionengine.fetch
A dummy counter handling context for fetch tasks
FetchContext() - Constructor for class org.apache.pig.backend.hadoop.executionengine.fetch.FetchContext
 
fetchFile(Properties, String) - Static method in class org.apache.pig.impl.io.FileLocalizer
Ensures that the passed path is on the local file system, fetching it to the java.io.tmpdir if necessary.
FetchFileRet(File, boolean) - Constructor for class org.apache.pig.impl.io.FileLocalizer.FetchFileRet
 
fetchFiles(Properties, String) - Static method in class org.apache.pig.impl.io.FileLocalizer
Ensures that the passed files pointed to by path are on the local file system, fetching them to the java.io.tmpdir if necessary.
FetchLauncher - Class in org.apache.pig.backend.hadoop.executionengine.fetch
This class is responsible for executing the fetch task, saving the result to disk and do the necessary cleanup afterwards.
FetchLauncher(PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.fetch.FetchLauncher
 
FetchOptimizer - Class in org.apache.pig.backend.hadoop.executionengine.fetch
FetchOptimizer determines whether the entire physical plan is fetchable, meaning that the task's result can be directly read (fetched) from the underlying storage rather than creating MR jobs.
FetchOptimizer() - Constructor for class org.apache.pig.backend.hadoop.executionengine.fetch.FetchOptimizer
 
FetchPOStoreImpl - Class in org.apache.pig.backend.hadoop.executionengine.fetch
This class is used to have a POStore write the output to the underlying storage via a output collector/record writer in case of a fetch task.
FetchPOStoreImpl(PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.fetch.FetchPOStoreImpl
 
FetchProgressableReporter - Class in org.apache.pig.backend.hadoop.executionengine.fetch
A dummy ProgressableReporter used for fetch tasks
FetchProgressableReporter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.fetch.FetchProgressableReporter
 
fetchResource(String) - Static method in class org.apache.pig.impl.io.FileLocalizer
Ensures that the passed resource is available from the local file system, fetching it to a temporary directory.
FetchTaskContext - Class in org.apache.pig.backend.hadoop.executionengine.fetch
 
FetchTaskContext(FetchContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.fetch.FetchTaskContext
 
Field(String, ObjectInspector, int) - Constructor for class org.apache.pig.impl.util.hive.HiveUtils.Field
 
FIELD - Static variable in class org.apache.pig.piggybank.storage.avro.AvroSchema2Pig
 
FIELD_NAME - Static variable in class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
 
fieldDelimiter - Variable in class org.apache.pig.piggybank.storage.IndexedStorage
Delimiter to use between fields
FieldIsNullException - Exception in org.apache.pig.data
 
FieldIsNullException() - Constructor for exception org.apache.pig.data.FieldIsNullException
 
FieldIsNullException(String) - Constructor for exception org.apache.pig.data.FieldIsNullException
 
fieldNames() - Method in class org.apache.pig.ResourceSchema
Get all field names.
FieldSchema(String, byte) - Constructor for class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Constructor for any type.
FieldSchema(String, Schema) - Constructor for class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Constructor for tuple fields.
FieldSchema(String, Schema, byte) - Constructor for class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Constructor for tuple fields.
FieldSchema(Schema.FieldSchema) - Constructor for class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Copy Constructor.
fieldSchema - Variable in class org.apache.pig.newplan.logical.expression.LogicalExpression
 
file - Variable in class org.apache.pig.impl.io.FileLocalizer.FetchFileRet
 
file() - Method in class org.apache.pig.parser.SourceLocation
 
FILE_BYTES_READ - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
 
FILE_BYTES_WRITTEN - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
 
FILE_CONCATENATION_THRESHOLD - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
FILE_CONCATENATION_THRESHOLD - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
FILE_EXTENSION_LOADERS - Static variable in class org.apache.pig.piggybank.storage.allloader.LoadFuncHelper
 
FILE_SYSTEM_NAME - Static variable in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
 
FileBasedOutputSizeReader - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Class that computes the size of output for file-based systems.
FileBasedOutputSizeReader() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.FileBasedOutputSizeReader
 
fileExists(String, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
fileExists(String, DataStorage) - Static method in class org.apache.pig.impl.io.FileLocalizer
FileInputHandler - Class in org.apache.pig.impl.streaming
FileInputHandler handles the input for the Pig-Streaming executable in an asynchronous manner by feeding it input via an external file specified by the user.
FileInputHandler(StreamingCommand.HandleSpec) - Constructor for class org.apache.pig.impl.streaming.FileInputHandler
 
FileInputLoadFunc - Class in org.apache.pig
This class provides an implementation of OrderedLoadFunc interface which can be optionally re-used by LoadFuncs that use FileInputFormat, by having this as a super class
FileInputLoadFunc() - Constructor for class org.apache.pig.FileInputLoadFunc
 
FileList - Class in org.apache.pig.data
This class extends ArrayList to add a finalize() that calls delete on the files .
FileList(int) - Constructor for class org.apache.pig.data.FileList
 
FileList() - Constructor for class org.apache.pig.data.FileList
 
FileList(LinkedList<File>) - Constructor for class org.apache.pig.data.FileList
 
FileLocalizer - Class in org.apache.pig.impl.io
 
FileLocalizer() - Constructor for class org.apache.pig.impl.io.FileLocalizer
 
FileLocalizer.DataStorageInputStreamIterator - Class in org.apache.pig.impl.io
 
FileLocalizer.FetchFileRet - Class in org.apache.pig.impl.io
 
filename - Variable in class org.apache.pig.FileSplitComparable
 
fileName - Variable in class org.apache.pig.tools.pigstats.ScriptState
 
FILEOUTPUTCOMMITTER_MARKSUCCESSFULJOBS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
FileOutputHandler - Class in org.apache.pig.impl.streaming
FileOutputHandler handles the output from the Pig-Streaming executable in an asynchronous manner by reading it from an external file specified by the user.
FileOutputHandler(StreamingCommand.HandleSpec) - Constructor for class org.apache.pig.impl.streaming.FileOutputHandler
 
fileSize(String) - Method in class org.apache.pig.PigServer
Returns the length of a file in bytes which exists in the HDFS (accounts for replication).
FileSparkPigSplit() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
Spark executor's deserializer calls this, and we have to instantiate a default wrapped object
FileSparkPigSplit(PigSplit) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
FileSpec - Class in org.apache.pig.impl.io
A simple class that specifies a file name and storage function which is used to read/write it
FileSpec(String, FuncSpec) - Constructor for class org.apache.pig.impl.io.FileSpec
 
FileSplitComparable - Class in org.apache.pig
This class represents a relative position in a file.
FileSplitComparable() - Constructor for class org.apache.pig.FileSplitComparable
 
FileSplitComparable(String, long) - Constructor for class org.apache.pig.FileSplitComparable
 
filter - Variable in class org.apache.pig.builtin.BuildBloomBase
 
FilterAboveForeach - Class in org.apache.pig.newplan.logical.rules
This Rule moves Filter Above Foreach.
FilterAboveForeach(String) - Constructor for class org.apache.pig.newplan.logical.rules.FilterAboveForeach
 
FilterAboveForeach.FilterAboveForEachTransformer - Class in org.apache.pig.newplan.logical.rules
 
FilterAboveForEachTransformer() - Constructor for class org.apache.pig.newplan.logical.rules.FilterAboveForeach.FilterAboveForEachTransformer
 
FilterConstantCalculator - Class in org.apache.pig.newplan.logical.rules
 
FilterConstantCalculator(String, PigContext) - Constructor for class org.apache.pig.newplan.logical.rules.FilterConstantCalculator
 
FilterConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
Converter that converts an RDD to a filtered RRD using POFilter
FilterConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.FilterConverter
 
filteredPlan - Variable in class org.apache.pig.newplan.FilterExtractor
Plan that is created after all pushable filters are removed
filterExpr - Variable in class org.apache.pig.newplan.FilterExtractor
Final filterExpr after we are done
FilterExtractor - Class in org.apache.pig.newplan
Extracts filter predicates for interfaces implementing LoadPredicatePushdown
FilterExtractor(LogicalExpressionPlan) - Constructor for class org.apache.pig.newplan.FilterExtractor
 
FilterExtractor.KeyState - Class in org.apache.pig.newplan
 
FilterFunc - Class in org.apache.pig
 
FilterFunc() - Constructor for class org.apache.pig.FilterFunc
 
FINAL - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
Final() - Constructor for class org.apache.pig.builtin.AlgebraicBigDecimalMathBase.Final
 
Final() - Constructor for class org.apache.pig.builtin.AlgebraicBigIntegerMathBase.Final
 
Final() - Constructor for class org.apache.pig.builtin.AlgebraicByteArrayMathBase.Final
 
Final() - Constructor for class org.apache.pig.builtin.AlgebraicDoubleMathBase.Final
 
Final() - Constructor for class org.apache.pig.builtin.AlgebraicFloatMathBase.Final
 
Final() - Constructor for class org.apache.pig.builtin.AlgebraicIntMathBase.Final
 
Final() - Constructor for class org.apache.pig.builtin.AlgebraicLongMathBase.Final
 
Final() - Constructor for class org.apache.pig.builtin.AVG.Final
 
Final() - Constructor for class org.apache.pig.builtin.BigDecimalAvg.Final
 
Final() - Constructor for class org.apache.pig.builtin.BigDecimalMax.Final
 
Final() - Constructor for class org.apache.pig.builtin.BigDecimalMin.Final
 
Final() - Constructor for class org.apache.pig.builtin.BigDecimalSum.Final
 
Final() - Constructor for class org.apache.pig.builtin.BigIntegerAvg.Final
 
Final() - Constructor for class org.apache.pig.builtin.BigIntegerMax.Final
 
Final() - Constructor for class org.apache.pig.builtin.BigIntegerMin.Final
 
Final() - Constructor for class org.apache.pig.builtin.BigIntegerSum.Final
 
Final() - Constructor for class org.apache.pig.builtin.BuildBloom.Final
 
Final(String, String, String, String) - Constructor for class org.apache.pig.builtin.BuildBloom.Final
 
Final(String, String, String) - Constructor for class org.apache.pig.builtin.BuildBloom.Final
 
Final() - Constructor for class org.apache.pig.builtin.COR.Final
 
Final(String...) - Constructor for class org.apache.pig.builtin.COR.Final
 
Final() - Constructor for class org.apache.pig.builtin.COUNT.Final
 
Final() - Constructor for class org.apache.pig.builtin.COUNT_STAR.Final
 
Final() - Constructor for class org.apache.pig.builtin.COV.Final
 
Final(String...) - Constructor for class org.apache.pig.builtin.COV.Final
 
Final() - Constructor for class org.apache.pig.builtin.DateTimeMax.Final
 
Final() - Constructor for class org.apache.pig.builtin.DateTimeMin.Final
 
Final() - Constructor for class org.apache.pig.builtin.Distinct.Final
 
Final() - Constructor for class org.apache.pig.builtin.DoubleAvg.Final
 
Final() - Constructor for class org.apache.pig.builtin.DoubleMax.Final
 
Final() - Constructor for class org.apache.pig.builtin.DoubleMin.Final
 
Final() - Constructor for class org.apache.pig.builtin.DoubleSum.Final
 
Final() - Constructor for class org.apache.pig.builtin.FloatAvg.Final
 
Final() - Constructor for class org.apache.pig.builtin.FloatMax.Final
 
Final() - Constructor for class org.apache.pig.builtin.FloatMin.Final
 
Final(String) - Constructor for class org.apache.pig.builtin.HiveUDAF.Final
 
Final(String, String) - Constructor for class org.apache.pig.builtin.HiveUDAF.Final
 
Final() - Constructor for class org.apache.pig.builtin.IntAvg.Final
 
Final() - Constructor for class org.apache.pig.builtin.IntMax.Final
 
Final() - Constructor for class org.apache.pig.builtin.IntMin.Final
 
Final() - Constructor for class org.apache.pig.builtin.LongAvg.Final
 
Final() - Constructor for class org.apache.pig.builtin.LongMax.Final
 
Final() - Constructor for class org.apache.pig.builtin.LongMin.Final
 
Final() - Constructor for class org.apache.pig.builtin.LongSum.Final
 
Final() - Constructor for class org.apache.pig.builtin.MAX.Final
 
Final() - Constructor for class org.apache.pig.builtin.MIN.Final
 
Final() - Constructor for class org.apache.pig.builtin.StringMax.Final
 
Final() - Constructor for class org.apache.pig.builtin.StringMin.Final
 
Final() - Constructor for class org.apache.pig.builtin.SUM.Final
 
Final() - Constructor for class org.apache.pig.builtin.TOP.Final
 
Final(String) - Constructor for class org.apache.pig.builtin.TOP.Final
 
Final() - Constructor for class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField.Final
 
Final() - Constructor for class org.apache.pig.piggybank.evaluation.stats.COR.Final
Deprecated.
 
Final(String...) - Constructor for class org.apache.pig.piggybank.evaluation.stats.COR.Final
Deprecated.
 
Final() - Constructor for class org.apache.pig.piggybank.evaluation.stats.COV.Final
Deprecated.
 
Final(String...) - Constructor for class org.apache.pig.piggybank.evaluation.stats.COV.Final
Deprecated.
 
Final() - Constructor for class org.apache.pig.piggybank.evaluation.util.Top.Final
Deprecated.
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.BigDecimalGroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.BigIntegerGroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.BooleanGroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.ChararrayGroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.DataBagGroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.DataByteArrayGroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.DateTimeGroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.DoubleGroovyAlgebraicEvalFunc.Final
 
Final() - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.FloatGroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.IntegerGroovyAlgebraicEvalFunc.Final
 
Final() - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.LongGroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.LongGroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.MapGroovyAlgebraicEvalFunc.Final
 
Final(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.TupleGroovyAlgebraicEvalFunc.Final
 
Final() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.BagJrubyAlgebraicEvalFunc.Final
 
Final(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.BagJrubyAlgebraicEvalFunc.Final
 
Final() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.ChararrayJrubyAlgebraicEvalFunc.Final
 
Final(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.ChararrayJrubyAlgebraicEvalFunc.Final
 
Final() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.DataByteArrayJrubyAlgebraicEvalFunc.Final
 
Final(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.DataByteArrayJrubyAlgebraicEvalFunc.Final
 
Final() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.DoubleJrubyAlgebraicEvalFunc.Final
 
Final(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.DoubleJrubyAlgebraicEvalFunc.Final
 
Final() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.Final
 
Final(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.Final
 
Final() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.FloatJrubyAlgebraicEvalFunc.Final
 
Final(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.FloatJrubyAlgebraicEvalFunc.Final
 
Final() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.IntegerJrubyAlgebraicEvalFunc.Final
 
Final(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.IntegerJrubyAlgebraicEvalFunc.Final
 
Final() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.LongJrubyAlgebraicEvalFunc.Final
 
Final(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.LongJrubyAlgebraicEvalFunc.Final
 
Final() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.MapJrubyAlgebraicEvalFunc.Final
 
Final(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.MapJrubyAlgebraicEvalFunc.Final
 
Final() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.TupleJrubyAlgebraicEvalFunc.Final
 
Final(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.TupleJrubyAlgebraicEvalFunc.Final
 
finalize() - Method in class org.apache.pig.data.FileList
 
find(ThreadContext, IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubySchema
Given a field name this string will search the RubySchema for a FieldSchema with that name and return it encapsulated in a Schema.
findAlgebraicOps(List<PhysicalPlan>) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil
find algebraic operators and also check if the foreach statement is suitable for combiner use
findByAlias(String) - Method in class org.apache.pig.newplan.logical.relational.LogicalPlan
 
findContainingJar(Class) - Static method in class org.apache.pig.impl.util.JarManager
Find a jar that contains a class of the same name, if any.
findField(long) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Look for the index of the field that contains the specified uid
findFieldSchema(String) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Find a field schema instance in this FieldSchema hierarchy (including "this") that matches the given canonical name.
findFieldSchema(String) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Look for a FieldSchema instance in the schema hierarchy which has the given canonical name.
findGenerate(LOForEach) - Static method in class org.apache.pig.newplan.logical.rules.OptimizerUtils
Find generate op from the foreach operator.
findMetaFile(String, String, Configuration) - Method in class org.apache.pig.builtin.JsonMetadata
.
findPigDataType(String) - Static method in class org.apache.pig.piggybank.storage.hiverc.HiveRCSchemaUtil
Returns the pig DataType for the hive type
FindQuantiles - Class in org.apache.pig.impl.builtin
 
FindQuantiles() - Constructor for class org.apache.pig.impl.builtin.FindQuantiles
 
FindQuantiles(String[]) - Constructor for class org.apache.pig.impl.builtin.FindQuantiles
 
FindQuantilesTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.udf
 
FindQuantilesTez() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.FindQuantilesTez
 
FindQuantilesTez(String[]) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.FindQuantilesTez
 
findReacheableInnerLoadFromBoundaryProject(ProjectExpression) - Static method in class org.apache.pig.newplan.logical.relational.LOForEach
 
findReferent() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
Find the LogicalRelationalOperator that this projection refers to.
findType(Object) - Static method in class org.apache.pig.data.DataType
Determine the datatype of an object.
findType(Type) - Static method in class org.apache.pig.data.DataType
Given a Type object determine the data type it represents.
findTypeByName(String) - Static method in class org.apache.pig.data.DataType
Get the type code from the type name
findTypeClass(byte) - Static method in class org.apache.pig.data.DataType
 
findTypeFromClassName(String) - Static method in class org.apache.pig.backend.hadoop.HDataType
 
findTypeFromNullableWritable(PigNullableWritable) - Static method in class org.apache.pig.backend.hadoop.HDataType
 
findTypeName(Object) - Static method in class org.apache.pig.data.DataType
Get the type name.
findTypeName(byte) - Static method in class org.apache.pig.data.DataType
Get the type name from the type byte code
finish() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
finish() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
finish() - Method in class org.apache.pig.builtin.HiveUDF
 
finish() - Method in class org.apache.pig.EvalFunc
Placeholder for cleanup to be performed at the end.
finish() - Method in class org.apache.pig.FilterFunc
Placeholder for cleanup to be performed at the end.
finish() - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
finish() - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
first - Variable in class org.apache.pig.impl.util.Pair
 
fixDuplicateUids(List<LogicalSchema.LogicalFieldSchema>) - Static method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
In the case of an operation which manipualtes columns (such as a foreach or a join) it is possible for multiple columns to have been derived from the same column and thus have duplicate UID's.
FixedByteArrayOutputStream - Class in org.apache.pig.backend.hadoop.accumulo
Uses a fixed length array and will not grow in size dynamically like the ByteArrayOutputStream.
FixedByteArrayOutputStream(byte[]) - Constructor for class org.apache.pig.backend.hadoop.accumulo.FixedByteArrayOutputStream
 
FixedWidthLoader - Class in org.apache.pig.piggybank.storage
A fixed-width file loader.
FixedWidthLoader() - Constructor for class org.apache.pig.piggybank.storage.FixedWidthLoader
 
FixedWidthLoader(String) - Constructor for class org.apache.pig.piggybank.storage.FixedWidthLoader
 
FixedWidthLoader(String, String) - Constructor for class org.apache.pig.piggybank.storage.FixedWidthLoader
 
FixedWidthLoader(String, String, String) - Constructor for class org.apache.pig.piggybank.storage.FixedWidthLoader
 
FixedWidthLoader.FixedWidthField - Class in org.apache.pig.piggybank.storage
 
FixedWidthStorer - Class in org.apache.pig.piggybank.storage
Stores Pig records in a fixed-width file format.
FixedWidthStorer() - Constructor for class org.apache.pig.piggybank.storage.FixedWidthStorer
 
FixedWidthStorer(String) - Constructor for class org.apache.pig.piggybank.storage.FixedWidthStorer
 
FixedWidthStorer(String, String) - Constructor for class org.apache.pig.piggybank.storage.FixedWidthStorer
 
fixMapProjects(PhysicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil.fixMapProjects
 
fixMapProjects(PhysicalPlan, PlanWalker<PhysicalOperator, PhysicalPlan>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil.fixMapProjects
 
fixSchema(ResourceSchema) - Method in class org.apache.pig.builtin.JsonStorage
 
fixSchemaAddTupleInBag(Schema) - Static method in class org.apache.pig.newplan.logical.Util
If schema argument has fields where a bag does not contain a tuple schema, it inserts a tuple schema.
flatten(ThreadContext, Block) - Method in class org.apache.pig.scripting.jruby.RubyDataBag
This is a convenience method which will run the given block on the first element of each tuple contained.
FLOAT - Static variable in class org.apache.pig.data.BinInterSedes
 
FLOAT - Static variable in class org.apache.pig.data.DataType
 
FloatAbs - Class in org.apache.pig.builtin
 
FloatAbs() - Constructor for class org.apache.pig.builtin.FloatAbs
 
FloatAbs - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
FloatAbs() - Constructor for class org.apache.pig.piggybank.evaluation.math.FloatAbs
Deprecated.
 
FloatAvg - Class in org.apache.pig.builtin
This method should never be used directly, use AVG.
FloatAvg() - Constructor for class org.apache.pig.builtin.FloatAvg
 
FloatAvg.Final - Class in org.apache.pig.builtin
 
FloatAvg.Initial - Class in org.apache.pig.builtin
 
FloatAvg.Intermediate - Class in org.apache.pig.builtin
 
FloatCopySign - Class in org.apache.pig.piggybank.evaluation.math
math.copySign implements a binding to the Java function Math.copySign(float,float).
FloatCopySign() - Constructor for class org.apache.pig.piggybank.evaluation.math.FloatCopySign
 
FloatGetExponent - Class in org.apache.pig.piggybank.evaluation.math
math.getExponent implements a binding to the Java function Math.getExponent(double).
FloatGetExponent() - Constructor for class org.apache.pig.piggybank.evaluation.math.FloatGetExponent
 
FloatGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.FloatGroovyAlgebraicEvalFunc
 
FloatJrubyAlgebraicEvalFunc(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.FloatJrubyAlgebraicEvalFunc
 
FloatMax - Class in org.apache.pig.builtin
This method should never be used directly, use MAX.
FloatMax() - Constructor for class org.apache.pig.builtin.FloatMax
 
FloatMax - Class in org.apache.pig.piggybank.evaluation.math
math.max implements a binding to the Java function Math.max(int,int) for computing the the max value of the arguments.
FloatMax() - Constructor for class org.apache.pig.piggybank.evaluation.math.FloatMax
 
FloatMax.Final - Class in org.apache.pig.builtin
 
FloatMax.Intermediate - Class in org.apache.pig.builtin
 
FloatMin - Class in org.apache.pig.builtin
This method should never be used directly, use MIN.
FloatMin() - Constructor for class org.apache.pig.builtin.FloatMin
 
FloatMin - Class in org.apache.pig.piggybank.evaluation.math
math.min implements a binding to the Java function Math.min(int,int) for computing the the min value of the arguments.
FloatMin() - Constructor for class org.apache.pig.piggybank.evaluation.math.FloatMin
 
FloatMin.Final - Class in org.apache.pig.builtin
 
FloatMin.Intermediate - Class in org.apache.pig.builtin
 
FloatNextAfter - Class in org.apache.pig.piggybank.evaluation.math
math.nextAfter implements a binding to the Java function Math.nextAfter(double,double).
FloatNextAfter() - Constructor for class org.apache.pig.piggybank.evaluation.math.FloatNextAfter
 
FloatNextup - Class in org.apache.pig.piggybank.evaluation.math
math.NEXTUP implements a binding to the Java function Math.nextUp(double).
FloatNextup() - Constructor for class org.apache.pig.piggybank.evaluation.math.FloatNextup
 
FloatRound - Class in org.apache.pig.builtin
ROUND implements a binding to the Java function Math.round(float).
FloatRound() - Constructor for class org.apache.pig.builtin.FloatRound
 
FloatRound - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
FloatRound() - Constructor for class org.apache.pig.piggybank.evaluation.math.FloatRound
Deprecated.
 
FloatRoundTo - Class in org.apache.pig.builtin
ROUND_TO safely rounds a number to a given precision by using an intermediate BigDecimal.
FloatRoundTo() - Constructor for class org.apache.pig.builtin.FloatRoundTo
 
FloatSchema - Static variable in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
 
FloatSignum - Class in org.apache.pig.piggybank.evaluation.math
math.SIGNUM implements a binding to the Java function Math.signum(float).
FloatSignum() - Constructor for class org.apache.pig.piggybank.evaluation.math.FloatSignum
 
FloatSum - Class in org.apache.pig.builtin
This method should never be used directly, use SUM.
FloatSum() - Constructor for class org.apache.pig.builtin.FloatSum
 
FloatUlp - Class in org.apache.pig.piggybank.evaluation.math
math.ULP implements a binding to the Java function Math.ulp(float).
FloatUlp() - Constructor for class org.apache.pig.piggybank.evaluation.math.FloatUlp
 
FLOOR - Class in org.apache.pig.builtin
FLOOR implements a binding to the Java function Math.floor(double).
FLOOR() - Constructor for class org.apache.pig.builtin.FLOOR
 
FLOOR - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use FLOOR
FLOOR() - Constructor for class org.apache.pig.piggybank.evaluation.math.FLOOR
Deprecated.
 
ForEachConstantCalculator - Class in org.apache.pig.newplan.logical.rules
 
ForEachConstantCalculator(String, PigContext) - Constructor for class org.apache.pig.newplan.logical.rules.ForEachConstantCalculator
 
ForEachConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
Convert that is able to convert an RRD to another RRD using a POForEach
ForEachConverter(JobConf) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.ForEachConverter
 
ForEachUserSchemaVisitor - Class in org.apache.pig.newplan.logical.visitor
 
ForEachUserSchemaVisitor(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.ForEachUserSchemaVisitor
 
format(DataBag) - Static method in class org.apache.pig.impl.util.BagFormat
 
format(Tuple) - Static method in class org.apache.pig.impl.util.TupleFormat
Default implementation of format of tuple (each filed is delimited by tab)
found() - Method in class org.apache.pig.newplan.logical.visitor.ScalarVariableValidator.ProjectFinder
 
fragment - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
FRAMEWORK_NAME - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
FRJoinConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
FRJoinConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.FRJoinConverter
 
fromEdges - Variable in class org.apache.pig.newplan.BaseOperatorPlan
 
fromString(String) - Static method in class org.apache.pig.ExecTypeProvider
 
fromString(String) - Static method in class org.apache.pig.impl.plan.OperatorKey
 
FrontendException - Exception in org.apache.pig.impl.logicalLayer
 
FrontendException() - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with null as the error message.
FrontendException(String) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified cause.
FrontendException(String, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(String, int, SourceLocation) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(String, int) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(String, int, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(String, int, byte) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(String, int, byte, Throwable, SourceLocation) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(String, int, boolean) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(String, int, byte, boolean) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
FrontendException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
FrontendException(Operator, String) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(Operator, String, int) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(Operator, String, int, byte) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(Operator, String, int, byte, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(Operator, String, int, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message and cause.
FrontendException(Operator, String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.FrontendException
Create a new FrontendException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
fs - Variable in class org.apache.pig.backend.hadoop.datastorage.HPath
 
fs(String) - Static method in class org.apache.pig.scripting.js.JSPig
See Pig
fs(String) - Static method in class org.apache.pig.scripting.Pig
Run a filesystem command.
FS_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
 
FS_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
Deprecated.
FS_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
FS_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
FullMapCollector(OperatorPlan, Set<Long>) - Constructor for class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.FullMapCollector
 
fullPath(String, DataStorage) - Static method in class org.apache.pig.impl.io.FileLocalizer
fullPath(String, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
FUNC_CALL - Static variable in class org.apache.pig.piggybank.storage.avro.AvroStorageLog
 
FuncSpec - Class in org.apache.pig
Class to represent a UDF specification.
FuncSpec(String, String) - Constructor for class org.apache.pig.FuncSpec
 
FuncSpec(String, String[]) - Constructor for class org.apache.pig.FuncSpec
 
FuncSpec(String, String[], Schema) - Constructor for class org.apache.pig.FuncSpec
 
FuncSpec(String) - Constructor for class org.apache.pig.FuncSpec
 
FuncSpec(String, Schema) - Constructor for class org.apache.pig.FuncSpec
 
Function<S,T> - Interface in org.apache.pig
A convenience typedef that ties into both google's Function and ExceptionalFunction.
FunctionWrapperEvalFunc - Class in org.apache.pig.builtin
EvalFunc that wraps an implementation of the Function interface, which is passed as a String in the constructor.
FunctionWrapperEvalFunc(String) - Constructor for class org.apache.pig.builtin.FunctionWrapperEvalFunc
Takes the class name of a Function, initializes it using the default constructor and passes it to FunctionWrapperEvalFunc(ExceptionalFunction function).
FunctionWrapperEvalFunc(Function) - Constructor for class org.apache.pig.builtin.FunctionWrapperEvalFunc
Determines the input and output types of the Function and initializes the superclass.
FunctionWrapperEvalFunc(ExceptionalFunction) - Constructor for class org.apache.pig.builtin.FunctionWrapperEvalFunc
Determines the input and output types of the Function and initializes the superclass.
FuncUtils - Class in org.apache.pig.builtin
 
FuncUtils() - Constructor for class org.apache.pig.builtin.FuncUtils
 

G

genAllTypes() - Static method in class org.apache.pig.data.DataType
Get an array of all type values.
GENERATED_CLASSES_KEY - Static variable in class org.apache.pig.PigConstants
This key is used in the job conf to let the various jobs know what code was generated.
generatedCodeCompareTo(SchemaTuple<?>, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeCompareToSpecific(T) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetBigDecimal(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetBigInteger(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetBoolean(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetBytes(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetDataBag(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetDateTime(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetDouble(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetField(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetFloat(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetInt(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetLong(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetMap(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetString(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeGetTuple(int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeHashCode() - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeNullsArray() - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeReadFields(DataInput, boolean[]) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSet(SchemaTuple<?>, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetBigDecimal(int, BigDecimal) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetBigInteger(int, BigInteger) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetBoolean(int, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetBytes(int, byte[]) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetDataBag(int, DataBag) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetDateTime(int, DateTime) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetDouble(int, double) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetField(int, Object) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetFloat(int, float) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetInt(int, int) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetIterator(Iterator<Object>) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetLong(int, long) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetMap(int, Map<String, Object>) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetSpecific(T) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetString(int, String) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSetTuple(int, Tuple) - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeSize() - Method in class org.apache.pig.data.SchemaTuple
 
generatedCodeWriteElements(DataOutput) - Method in class org.apache.pig.data.SchemaTuple
 
generateNestedSchema(byte, byte...) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
generateSchemaTuple(Schema, boolean, int, File, SchemaTupleClassGenerator.GenContext...) - Static method in class org.apache.pig.data.SchemaTupleClassGenerator
This class actually generates the code for a given Schema.
GENERIC_WRITABLECOMPARABLE - Static variable in class org.apache.pig.data.BinInterSedes
 
GENERIC_WRITABLECOMPARABLE - Static variable in class org.apache.pig.data.DataType
Internal use only; used to store WriteableComparable objects for creating ordered index in MergeJoin.
genericGetNext(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
genericGetNext(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
genericGetNext(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Mod
 
genericGetNext(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
genericGetNext(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
genericGetNext(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
GenericInvoker<T> - Class in org.apache.pig.builtin
The generic Invoker class does all the common grunt work of setting up an invoker.
GenericInvoker() - Constructor for class org.apache.pig.builtin.GenericInvoker
 
GenericInvoker(String) - Constructor for class org.apache.pig.builtin.GenericInvoker
 
GenericInvoker(String, String) - Constructor for class org.apache.pig.builtin.GenericInvoker
 
GenericInvoker(String, String, String) - Constructor for class org.apache.pig.builtin.GenericInvoker
 
GenericSparkPigSplit() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
Spark executor's deserializer calls this, and we have to instantiate a default wrapped object
GenericSparkPigSplit(PigSplit) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
genNameToTypeMap() - Static method in class org.apache.pig.data.DataType
Get a map of type names to type values.
genOpKey(String) - Static method in class org.apache.pig.impl.plan.OperatorKey
Utility function for creating operator keys.
genSubstitutedFile(BufferedReader, Writer) - Method in class org.apache.pig.tools.parameters.ParameterSubstitutionPreprocessor
This is the main API that takes script template and produces pig script
genSubstitutedFile(BufferedReader, Writer, String[], String[]) - Method in class org.apache.pig.tools.parameters.ParameterSubstitutionPreprocessor
 
genTypeToNameMap() - Static method in class org.apache.pig.data.DataType
Get a map of type values to type names.
get() - Method in class org.apache.pig.backend.hadoop.BigDecimalWritable
 
get() - Method in class org.apache.pig.backend.hadoop.BigIntegerWritable
 
get() - Method in class org.apache.pig.backend.hadoop.DateTimeWritable
 
get() - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
get() - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchTaskContext
 
get() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRTaskContext
 
get(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin.TupleToMapKey
 
get(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin.TuplesToSchemaTupleList
 
get() - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigContext
 
get() - Method in class org.apache.pig.backend.hadoop.executionengine.TaskContext
 
get() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezTaskContext
 
get(String) - Method in class org.apache.pig.builtin.mock.Storage.Data
 
get(int) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
get() - Method in class org.apache.pig.data.DataByteArray
Get the underlying byte array.
get(int) - Method in class org.apache.pig.data.DefaultTuple
Get the value in a given field.
get(int) - Method in class org.apache.pig.data.SchemaTuple
 
get(int) - Method in class org.apache.pig.data.TargetedTuple
 
get(int) - Method in interface org.apache.pig.data.Tuple
Get the value in a given field.
get(int) - Method in class org.apache.pig.data.UnlimitedNullTuple
 
get() - Method in class org.apache.pig.data.utils.StructuresHelper.SchemaKey
 
get(int) - Method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
get(Object) - Method in class org.apache.pig.impl.util.avro.AvroMapWrapper
 
get(int) - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
get(K) - Method in class org.apache.pig.impl.util.MultiMap
Get the collection of values associated with a given key.
get(int) - Method in class org.apache.pig.pen.util.ExampleTuple
 
get(ThreadContext, IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubySchema
This is the ruby method which allows people to access elements of the RubySchema object.
get(ThreadContext, IRubyObject, IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubySchema
This is a version of [] which allows the range to be specified as such: [1,2].
get(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubySchema
This method allows access into the Schema nested in the encapsulated Schema.
get() - Static method in class org.apache.pig.scripting.ScriptPigContext
 
get() - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRScriptState
 
get() - Static method in class org.apache.pig.tools.pigstats.PigStats
 
get() - Static method in class org.apache.pig.tools.pigstats.ScriptState
 
get() - Static method in class org.apache.pig.tools.pigstats.tez.TezScriptState
 
getAbsolutePath(String, Path) - Static method in class org.apache.pig.LoadFunc
Construct the absolute path from the file location and the current directory.
getAcceptedType(Schema) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
extract schema from a nullable union
getAccumulativeBatchSize() - Static method in class org.apache.pig.backend.hadoop.executionengine.util.AccumulatorOptimizerUtil
 
getActiveContainer() - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
getActiveContainer() - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
getAddedFields() - Method in class org.apache.pig.impl.plan.ProjectionMap
 
getAggregate() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigHadoopLogger
 
getAlias() - Method in interface org.apache.pig.backend.executionengine.ExecJob
Returns the alias of relation generated by this job
getAlias() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getAlias() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getAlias() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator.OriginalLocation
 
getAlias() - Method in class org.apache.pig.LoadPushDown.RequiredField
 
getAlias() - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
Get the alias of this operator.
getAlias() - Method in exception org.apache.pig.parser.DuplicatedSchemaAliasException
 
getAlias() - Method in exception org.apache.pig.parser.UndefinedAliasException
 
getAlias() - Method in class org.apache.pig.tools.pigstats.JobStats
 
getAlias() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getAlias(MapReduceOper) - Method in class org.apache.pig.tools.pigstats.mapreduce.MRScriptState
 
getAlias() - Method in class org.apache.pig.tools.pigstats.OutputStats
 
getAlias(SparkOperator) - Method in class org.apache.pig.tools.pigstats.spark.SparkScriptState.SparkScriptInfo
 
getAlias() - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState.TezDAGScriptInfo
 
getAlias(TezOperator) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState.TezDAGScriptInfo
 
getAliases() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
getAliases() - Method in class org.apache.pig.PigServer
Return a map containing the logical plan associated with each alias.
getAliasKeySet() - Method in class org.apache.pig.PigServer
Get the set of all current aliases.
getAliasLocation() - Method in class org.apache.pig.tools.pigstats.JobStats
 
getAliasLocation() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getAliasLocation(MapReduceOper) - Method in class org.apache.pig.tools.pigstats.mapreduce.MRScriptState
 
getAliasLocation(SparkOperator) - Method in class org.apache.pig.tools.pigstats.spark.SparkScriptState.SparkScriptInfo
 
getAliasLocation() - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState.TezDAGScriptInfo
 
getAliasLocation(TezOperator) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState.TezDAGScriptInfo
 
getAliasString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getAll() - Method in class org.apache.pig.data.DefaultTuple
Get all of the fields in the tuple as a list.
getAll() - Method in class org.apache.pig.data.SchemaTuple
 
getAll() - Method in class org.apache.pig.data.TargetedTuple
 
getAll() - Method in interface org.apache.pig.data.Tuple
Get all of the fields in the tuple as a list.
getAll() - Method in class org.apache.pig.data.UnlimitedNullTuple
 
getAll() - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
getAll() - Method in class org.apache.pig.pen.util.ExampleTuple
 
getAllErrorMessages() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getAllErrorMessages() - Method in class org.apache.pig.tools.pigstats.mapreduce.SimplePigStats
 
getAllErrorMessages() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getAllErrorMessages() - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
getAllErrorMessages() - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
getAllFileRecursively(List<FileStatus>, Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
Get all files recursively from the given list of files
getAllFilesRecursively(Set<Path>, Configuration) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
Returns all non-hidden files recursively inside the base paths given
getAllListeners() - Method in class org.apache.pig.tools.pigstats.ScriptState
 
getAllStats() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getAllStats() - Method in class org.apache.pig.tools.pigstats.mapreduce.SimplePigStats
 
getAllStats() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getAllStats() - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
getAllStats() - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
getAmendKey() - Method in class org.apache.pig.data.AmendableTuple
 
getAnnotation(String) - Method in class org.apache.pig.newplan.Operator
Look to see if a node is annotated.
getAnnotationCanonicalName() - Method in enum org.apache.pig.data.SchemaTupleClassGenerator.GenContext
 
getAppendedField(int) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
getAppendedFields() - Method in class org.apache.pig.data.AppendableSchemaTuple
 
getApplicationId() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
getArgStringFromSpec(String) - Static method in class org.apache.pig.FuncSpec
Get the argument values passed to the func spec.
getArgToFuncMapping() - Method in class org.apache.pig.builtin.ABS
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.AddDuration
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.AVG
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.CONCAT
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.COUNT
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.DaysBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.DoubleBase
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.DoubleRoundTo
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.ENDSWITH
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.FloatRoundTo
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.GetDay
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.GetHour
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.GetMilliSecond
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.GetMinute
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.GetMonth
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.GetSecond
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.GetWeek
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.GetWeekYear
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.GetYear
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.HoursBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.LAST_INDEX_OF
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.LOWER
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.LTRIM
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.MAX
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.MilliSecondsBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.MIN
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.MinutesBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.MonthsBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.REGEX_EXTRACT
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.REGEX_EXTRACT_ALL
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.REPLACE
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.ROUND
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.ROUND_TO
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.RTRIM
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.SecondsBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.SIZE
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.STARTSWITH
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.STRSPLIT
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.STRSPLITTOBAG
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.SUBSTRING
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.SubtractDuration
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.SUM
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.ToDate
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.TOKENIZE
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.ToMilliSeconds
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.TOP
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.ToString
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.ToUnixTime
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.TRIM
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.UPPER
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.WeeksBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.YearsBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.EvalFunc
Allow a UDF to specify type specific implementations of itself.
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.convert.CustomFormatToISO
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.convert.ISOToUnix
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.convert.UnixToISO
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISODaysBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOHoursBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOMinutesBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOMonthsBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOSecondsBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOYearsBetween
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.DiffDate
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToDay
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToHour
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToMinute
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToMonth
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToSecond
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToWeek
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToYear
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.ABS
Deprecated.
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.copySign
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.DoubleBase
Deprecated.
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.DoubleDoubleBase
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.getExponent
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.MAX
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.MIN
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.nextAfter
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.NEXTUP
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.ROUND
Deprecated.
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.SCALB
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.SIGNUM
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.math.ULP
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.string.HashFNV
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.string.RegexExtract
Deprecated.
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.string.RegexExtractAll
Deprecated.
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.string.RegexMatch
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.string.REPLACE_MULTI
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.string.UPPER
Deprecated.
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.util.apachelogparser.DateExtractor
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.util.apachelogparser.HostExtractor
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.util.apachelogparser.SearchEngineExtractor
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.util.apachelogparser.SearchTermExtractor
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.util.SearchQuery
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.util.Top
Deprecated.
 
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.xml.XPath
Returns argument schemas of the UDF.
getArgToFuncMapping() - Method in class org.apache.pig.piggybank.evaluation.xml.XPathAll
Returns argument schemas of the UDF.
getArguments() - Method in class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
getArrayElements(Object) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
Called by the implementation of GenericDatumWriter.writeArray(org.apache.avro.Schema, java.lang.Object, org.apache.avro.io.Encoder) to enumerate array elements.
getArraySize(Object) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
Called by the implementation of GenericDatumWriter.writeArray(org.apache.avro.Schema, java.lang.Object, org.apache.avro.io.Encoder) to get the size of an array.
getAscendingCol() - Method in class org.apache.pig.newplan.logical.relational.LORank
 
getAscendingCols() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
getAscendingCols() - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
getAscendingColumns() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
getAscs() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SortKeyInfo
 
getAttachedLogicalOperator() - Method in class org.apache.pig.newplan.logical.expression.ScalarExpression
 
getAttachedRelationalOp() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
getAttributes(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter
 
getAttributes(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.DotPOPrinter
 
getAttributes(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter
 
getAttributes(E) - Method in class org.apache.pig.impl.plan.DotPlanDumper
Used to generate the the attributes of a node
getAttributes(Operator) - Method in class org.apache.pig.newplan.DotPlanDumper
Used to generate the the attributes of a node
getAttributes(Operator) - Method in class org.apache.pig.newplan.logical.DotLOPrinter
 
getAuthorizations(CommandLine) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
getAvgMapTime() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getAvgMapTime() instead.
getAvgMapTime() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getAvgMapTime() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getAvgMapTime() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getAvgMapTime() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getAvgRecordSize() - Method in class org.apache.pig.ResourceStatistics
 
getAvgREduceTime() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getAvgREduceTime() instead.
getAvgREduceTime() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getAvgREduceTime() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getAvgREduceTime() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getAvgREduceTime() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getAvroSchema(String, Job) - Method in class org.apache.pig.builtin.AvroStorage
Reads the avro schema at the specified location.
getAvroSchema(Path[], Job) - Method in class org.apache.pig.builtin.AvroStorage
Reads the avro schemas at the specified location.
getAvroSchema(Path[], Job) - Method in class org.apache.pig.builtin.TrevniStorage
 
getAvroSchema(Set<Path>, Configuration) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
Get avro schema of first input file that matches the location pattern.
getAvroSchema(Path, FileSystem) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
Get avro schema of input path.
getBag() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getBag() - Method in class org.apache.pig.scripting.jruby.RubyDataBag
 
getBagBegin() - Method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
getBagColumns() - Method in class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
getBagEnd() - Method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
getBasePlan() - Method in class org.apache.pig.newplan.OperatorSubPlan
 
getBigDecimal(int) - Method in class org.apache.pig.data.SchemaTuple
 
getBigDecimal(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
getBigInteger(int) - Method in class org.apache.pig.data.SchemaTuple
 
getBigInteger(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
getBinaryInputQueue() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
getBinaryOutputQueue() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
getBitByPos(byte, int) - Static method in class org.apache.pig.data.utils.BytesHelper
 
getBoolean(int) - Method in class org.apache.pig.data.SchemaTuple
 
getBoolean(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
getBranchFlag() - Method in class org.apache.pig.pen.util.PreOrderDepthFirstWalker
 
getBroadcastedVariableName() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POBroadcastSpark
 
getBroadcastedVars() - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigContext
 
getBuildTime() - Static method in class org.apache.pig.Main
Returns the built time of the Pig build being run.
getBytes(int) - Method in class org.apache.pig.data.SchemaTuple
 
getBytes(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
getBytes() - Method in class org.apache.pig.tools.pigstats.InputStats
 
getBytes() - Method in class org.apache.pig.tools.pigstats.OutputStats
 
getBytesWritten() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getBytesWritten() - Method in class org.apache.pig.tools.pigstats.JobStats
Returns the total bytes written to user specified HDFS locations of this job.
getBytesWritten() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the total bytes written to user specified HDFS locations of this script.
getCacheFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getCacheFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.UdfCacheShipFilesVisitor
 
getCacheFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
getCacheFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getCacheFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPOUserFuncVisitor
 
getCacheFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOStreamVisitor
 
getCacheFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOUserFuncVisitor
 
getCacheFiles() - Method in class org.apache.pig.builtin.Bloom
 
getCacheFiles() - Method in class org.apache.pig.builtin.JsonStorage
 
getCacheFiles() - Method in class org.apache.pig.EvalFunc
Allow a UDF to specify a list of hdfs files it would like placed in the distributed cache.
getCacheFiles() - Method in class org.apache.pig.LoadFunc
Allow a LoadFunc to specify a list of files it would like placed in the distributed cache.
getCacheFiles() - Method in interface org.apache.pig.StoreResources
Allow a StoreFunc to specify a list of files it would like placed in the distributed cache.
getCacheLimit() - Method in class org.apache.pig.data.SelfSpillBag.MemoryLimits
Computes the number of objects that would fit into memory based on the memory limit and average size of each object.
getCacheSpecs() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get the list of files which need to be cached on the execute nodes.
getCacheStagingDir(Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
getCast() - Method in class org.apache.pig.impl.plan.ProjectionMap.Column
Check if the column is cast
getCastState() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
getCastState() - Method in class org.apache.pig.newplan.logical.relational.LOStream
 
getCastType() - Method in class org.apache.pig.impl.plan.ProjectionMap.Column
Get the data type of the cast
getCause() - Method in exception org.apache.pig.parser.ParserValidationException
 
getCause() - Method in exception org.apache.pig.parser.PlanGenerationFailureException
 
getChanges() - Method in class org.apache.pig.impl.plan.ProjectionMap
 
getCharContent(boolean) - Method in class org.apache.pig.impl.util.JavaCompilerHelper.JavaSourceFromString
 
getChildExpressions() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
Get the child expressions of this expression
getChildExpressions() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
Get the child expressions of this expression
getChildExpressions() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
Get the sub-expressions of this expression.
getChildExpressions() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
Get child expressions of this expression
getChildExpressions() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
Get child expression of this expression
getChildExpressions() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getChildExpressions() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getChildExpressions() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
Get child expressions of this expression
getChildExpressions() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
Get child expression of this expression
getChildExpressions() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryExpressionOperator
Get child expression of this expression
getClassForAlias(String) - Method in class org.apache.pig.impl.PigContext
 
getClassLoader() - Static method in class org.apache.pig.impl.PigContext
 
getClassName() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternNode
 
getClassName() - Method in class org.apache.pig.FuncSpec
 
getClassNameFromSpec(String) - Static method in class org.apache.pig.FuncSpec
Parse the class name out of a function specification string.
getClassPath() - Method in class org.apache.pig.impl.util.JavaCompilerHelper
 
getClientSysProps() - Method in class org.apache.pig.impl.util.UDFContext
 
getClientSystemProps() - Method in class org.apache.pig.impl.util.UDFContext
Get the System Properties (Read only) as on the client machine from where Pig was launched.
getClonedGraph() - Method in class org.apache.pig.PigServer
Creates a clone of the current DAG
getCmd() - Method in exception org.apache.pig.parser.InvalidCommandException
 
getColAlias() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
getColIndex() - Method in class org.apache.pig.SortColInfo
 
getColName() - Method in class org.apache.pig.SortColInfo
 
getColNum() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
Column number this project references.
getColNum() - Method in class org.apache.pig.newplan.logical.relational.LOInnerLoad
 
getColumn() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getColumnChains() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SortKeyInfo
 
getColumnFamily() - Method in class org.apache.pig.backend.hadoop.accumulo.Column
 
getColumnFamily() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage.ColumnInfo
 
getColumnInfo(int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnChainInfo
 
getColumnInfoList() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
Returns the ColumnInfo list so external objects can inspect it.
getColumnInfos() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnChainInfo
 
getColumnName() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage.ColumnInfo
 
getColumnNumber(Configuration) - Static method in class org.apache.pig.piggybank.storage.hiverc.HiveRCOutputFormat
Returns the number of columns set in the conf for writers.
getColumnPrefix() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage.ColumnInfo
 
getColumnQualifier() - Method in class org.apache.pig.backend.hadoop.accumulo.Column
 
getColumns() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnInfo
 
getColumns() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getColumns(LogicalSchema, Set<Long>) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneHelper
 
getCombinePigSplits(List<InputSplit>, long, Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
 
getCombinerInMap() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
getCombinerInReducer() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
getCommand() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
Get the StreamingCommand for this StreamSpec.
getCommandArgs() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get the parsed command arguments.
getCommandForAlias(String) - Method in class org.apache.pig.impl.PigContext
Get the StreamingCommand for the given alias.
getCommandLine() - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
getCommandLine(String) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
getCommandLine() - Method in class org.apache.pig.tools.pigstats.ScriptState
 
getCommandString() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.NativeMapReduceOper
 
getCommandString() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.NativeSparkOperator
 
getCommandString() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.NativeTezOper
 
getComparator() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getComparatorClass() - Static method in class org.apache.pig.data.BinSedesTuple
 
getComparatorClass() - Static method in class org.apache.pig.data.DefaultTuple
 
getCompleteness(Operator, Map<Operator, DataBag>, Map<LogicalRelationalOperator, Collection<IdentityHashSet<Tuple>>>, boolean) - Static method in class org.apache.pig.pen.util.MetricEvaluation
 
getCompositeStream(InputStream, Properties) - Static method in class org.apache.pig.impl.util.Utils
 
getConciseness(Operator, Map<Operator, DataBag>, Map<LogicalRelationalOperator, Collection<IdentityHashSet<Tuple>>>, boolean) - Static method in class org.apache.pig.pen.util.MetricEvaluation
 
getCond() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
Get condition
getCondition() - Method in class org.apache.pig.newplan.logical.expression.BinCondExpression
Returns the operator which handles this condition
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SecondaryKeyPartitioner
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SkewedPartitioner
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBigDecimalRawComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBigIntegerRawComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBooleanRawComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBytesRawComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigDateTimeRawComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigDoubleRawComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigFloatRawComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigIntRawComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigLongRawComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSecondaryKeyComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTextRawComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleDefaultRawComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleSortComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
getConf() - Method in class org.apache.pig.builtin.RoundRobinPartitioner
Deprecated.
 
getConf() - Method in class org.apache.pig.data.BinInterSedes.BinInterSedesTupleRawComparator
 
getConf() - Method in class org.apache.pig.data.DefaultTuple.DefaultTupleRawComparator
 
getConf() - Method in class org.apache.pig.impl.PigContext
Deprecated.
getConf() - Method in class org.apache.pig.tools.pigstats.InputStats
 
getConf() - Method in class org.apache.pig.tools.pigstats.OutputStats
 
getConfiguration() - Method in interface org.apache.pig.backend.datastorage.DataStorage
Provides configuration information about the storage itself.
getConfiguration() - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
Retrieve configuration information for entity
getConfiguration() - Method in interface org.apache.pig.backend.executionengine.ExecJob
Get configuration information
getConfiguration() - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Returns the Properties representation of the ExecutionEngine configuration.
getConfiguration() - Method in class org.apache.pig.backend.hadoop.datastorage.HConfiguration
 
getConfiguration() - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
getConfiguration() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
getConfiguration() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
getConfiguration() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getConfiguration() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
getConfiguration() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
getConstantObjectInspector(Object) - Static method in class org.apache.pig.impl.util.hive.HiveUtils
 
getCounter(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchContext
 
getCounter(Enum<?>) - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchContext
 
getCounter(Enum<?>) - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchTaskContext
 
getCounter(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchTaskContext
 
getCounter(Enum<?>) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.IllustrateDummyReporter
 
getCounter(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.IllustrateDummyReporter
 
getCounter(Enum<?>) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRTaskContext
 
getCounter(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRTaskContext
 
getCounter(Enum<?>) - Method in class org.apache.pig.backend.hadoop.executionengine.TaskContext
 
getCounter(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.TaskContext
 
getCounter(Enum<?>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezTaskContext
 
getCounter(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezTaskContext
 
getCounter(Enum<?>) - Method in class org.apache.pig.tools.pigstats.PigStatusReporter
Deprecated.
use PigStatusReporter.incrCounter(java.lang.Enum<?>, long) instead. This method returns MR counter which is not compatible with Tez mode. Use incrCounter() that is compatible with both MR and Tez mode.
getCounter(String, String) - Method in class org.apache.pig.tools.pigstats.PigStatusReporter
Deprecated.
use PigStatusReporter.incrCounter(java.lang.Enum<?>, long) instead. This method returns MR counter which is not compatible with Tez mode. Use incrCounter() that is compatible with both MR and Tez mode.
getCounter(String) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounterGroup
 
getCounter(String, String) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounters
 
getCounter(Enum<?>) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounters
 
getCounterGroup() - Method in class org.apache.pig.builtin.FunctionWrapperEvalFunc
 
getCounterGroup() - Method in class org.apache.pig.TypedOutputEvalFunc
Incremented counters will use this as the counter group.
getCounterName(POStore) - Static method in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
getCounterName(POLoad) - Static method in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
getCounterPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
getCounters(Job) - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getCounters() - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStatusReporter
 
getCounters() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
getCounts() - Method in class org.apache.pig.impl.util.LineageTracer
 
getCounts() - Method in class org.apache.pig.pen.util.LineageTracer
 
getCredentials() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperPlan
 
getCrossKey() - Method in class org.apache.pig.impl.builtin.GFCross
 
getCrossKeys() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
getCrossKeys() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getCtorArgs() - Method in class org.apache.pig.FuncSpec
 
getCurrentDAG() - Method in class org.apache.pig.PigServer
Current DAG
getCurrentKey() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase.IllustratorContext
 
getCurrentKey() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl
 
getCurrentKey() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigRecordReader
 
getCurrentKey() - Method in class org.apache.pig.impl.io.BinStorageRecordReader
 
getCurrentKey() - Method in class org.apache.pig.impl.io.InterRecordReader
 
getCurrentKey() - Method in class org.apache.pig.impl.io.TFileRecordReader
 
getCurrentKey() - Method in class org.apache.pig.impl.util.avro.AvroArrayReader
 
getCurrentKey() - Method in class org.apache.pig.impl.util.avro.AvroRecordReader
 
getCurrentKey() - Method in class org.apache.pig.piggybank.storage.AllLoader.AllReader
 
getCurrentKey() - Method in class org.apache.pig.piggybank.storage.avro.PigAvroRecordReader
 
getCurrentKey() - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCRecordReader
 
getCurrentKey() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader
 
getCurrentKey() - Method in class org.apache.pig.piggybank.storage.XMLLoader.XMLRecordReader
 
getCurrentNode(PhysicalOperator, PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.SparkSecondaryKeyOptimizerUtil
 
getCurrentNode(PhysicalOperator, PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil
 
getCurrentValue() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase.IllustratorContext
 
getCurrentValue() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigRecordReader
 
getCurrentValue() - Method in class org.apache.pig.impl.io.BinStorageRecordReader
 
getCurrentValue() - Method in class org.apache.pig.impl.io.InterRecordReader
 
getCurrentValue() - Method in class org.apache.pig.impl.io.TFileRecordReader
 
getCurrentValue() - Method in class org.apache.pig.impl.util.avro.AvroArrayReader
Returns current value.
getCurrentValue() - Method in class org.apache.pig.impl.util.avro.AvroRecordReader
Returns current value.
getCurrentValue() - Method in class org.apache.pig.piggybank.storage.AllLoader.AllReader
 
getCurrentValue() - Method in class org.apache.pig.piggybank.storage.avro.PigAvroRecordReader
 
getCurrentValue() - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCRecordReader
 
getCurrentValue() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader
 
getCurrentValue() - Method in class org.apache.pig.piggybank.storage.XMLLoader.XMLRecordReader
 
getCustomPartitioner() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getCustomPartitioner() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
getCustomPartitioner() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
getCustomPartitioner() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
getCustomPartitioner() - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
getDAG() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
getDAGCounters() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
getDAGProgress() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
getDAGScriptInfo(String) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState
 
getDAGStatus() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
getData() - Method in class org.apache.pig.data.WritableByteArray
Returns the current contents of the buffer.
getData() - Method in class org.apache.pig.pen.ExampleGenerator
 
getData(Map<LOLoad, DataBag>) - Method in class org.apache.pig.pen.ExampleGenerator
 
getData() - Method in class org.apache.pig.pen.Illustrator
 
getDataBag(int) - Method in class org.apache.pig.data.SchemaTuple
 
getDataBag(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
getDataMap() - Method in class org.apache.pig.pen.IllustratorAttacher
 
getDataStorage() - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
 
getDataStorage() - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Returns the DataStorage the ExecutionEngine is using.
getDataStorage() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
getDataStorage() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
getDateTime(int) - Method in class org.apache.pig.data.SchemaTuple
 
getDateTime(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
GetDay - Class in org.apache.pig.builtin
GetDay extracts the day of a month from a DateTime object.
GetDay() - Constructor for class org.apache.pig.builtin.GetDay
 
getDBA() - Method in class org.apache.pig.scripting.jruby.RubyDataByteArray
 
getDefaultExtension() - Method in class org.apache.pig.impl.io.compress.BZip2CodecWithExtensionBZ
For historical reasons, Pig supports .bz and .bz2 for bzip2 extension
getDefaultJars() - Static method in class org.apache.pig.impl.util.JarManager
 
getDefaultLogLevel() - Method in class org.apache.pig.impl.PigContext
 
getDefaultParallel() - Method in class org.apache.pig.impl.PigContext
 
getDefaultParallelism() - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigContext
 
getDescription() - Method in class org.apache.pig.ResourceSchema.ResourceFieldSchema
Get a free form text description of this field.
getDetailedMessage() - Method in exception org.apache.pig.PigException
Returns the detailed message used by developers for debugging
getDeterminedSchema() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
getDfs() - Method in class org.apache.pig.impl.PigContext
 
getDiagnostics() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
getDisplayName() - Method in class org.apache.pig.tools.pigstats.spark.SparkCounter
 
getDisplayString() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getDisplayString() - Method in class org.apache.pig.tools.pigstats.InputStats
 
getDisplayString() - Method in class org.apache.pig.tools.pigstats.JobStats
 
getDisplayString() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getDisplayString() - Method in class org.apache.pig.tools.pigstats.mapreduce.SimplePigStats
 
getDisplayString() - Method in class org.apache.pig.tools.pigstats.OutputStats
 
getDisplayString() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the display message in pig grunt
getDisplayString() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getDisplayString() - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
getDisplayString() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
getDisplayString() - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
getDisplayString() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
getDistinct() - Method in class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil.DistinctPatcher
 
getDistinct(Tuple) - Method in class org.apache.pig.builtin.Distinct
 
getDistinctChanged() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SecondaryKeyOptimizer
 
getDouble(int) - Method in class org.apache.pig.data.SchemaTuple
 
getDouble(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
getDuration() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getEffectiveParallelism(int) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getEmptyPigStats() - Static method in class org.apache.pig.tools.pigstats.PigStatsUtil
Deprecated.
getEndCol() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
getEngine() - Static method in class org.apache.pig.scripting.groovy.GroovyScriptEngine
 
getEngineClassName() - Method in enum org.apache.pig.scripting.ScriptEngine.SupportedScriptLang
 
getEntries(Configuration, String) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
Extract elements from the Configuration whose keys match the given prefix
getEqClasses() - Method in class org.apache.pig.pen.ExampleGenerator
 
getEqClassesShared() - Method in class org.apache.pig.pen.Illustrator
 
getEquivalenceClasses() - Method in class org.apache.pig.pen.Illustrator
 
getError(FileSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceLauncher
Get the exception that caused a failure on the backend for a store location (if any).
getErrorCode() - Method in exception org.apache.pig.PigException
Returns the error code of the exception
getErrorCode() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the error code of PigException
getErrorHandler() - Method in interface org.apache.pig.ErrorHandling
This method is called to determine the ErrorHandler implementation that to handle errors in StoreFunc#putNext(Tuple)
getErrorMessage() - Method in class org.apache.pig.tools.pigstats.JobStats
 
getErrorMessage() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns error message string
getErrorMessages(Iterator<TaskReport>, String, boolean, PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
getErrorSource() - Method in class org.apache.pig.impl.PigContext
Check the execution mode and return the appropriate error source
getErrorSource() - Method in exception org.apache.pig.PigException
Returns the error source of the exception.
getErrorThrowable() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the error code of PigException
getEstimatedParallelism() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getEstimatedTotalParallelism() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.ParallelismSetter
 
getEstimatedTotalParallelism() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperPlan
 
getEvalFunc() - Method in class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
getEx() - Method in exception org.apache.pig.parser.InvalidPathException
 
getEx() - Method in exception org.apache.pig.parser.PlanGenerationFailureException
 
getExamples() - Method in class org.apache.pig.pen.ExampleGenerator
 
getExamples(String) - Method in class org.apache.pig.PigServer
 
getException() - Method in interface org.apache.pig.backend.executionengine.ExecJob
Get exceptions that happened during execution
getException() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getException() - Method in class org.apache.pig.tools.pigstats.JobStats
 
getExceptionFromString(String) - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
getExecConf(Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
getExecConf(Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezExecutionEngine
 
getExecType() - Method in class org.apache.pig.impl.PigContext
Returns the type of execution currently in effect.
getExecutable() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get the command to be executed.
getExecutableManager() - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Returns the ExecutableManager to be used in Pig Streaming.
getExecutableManager() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
getExecutableManager() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkExecutionEngine
 
getExecutableManager() - Method in class org.apache.pig.newplan.logical.relational.LOStream
 
getExecutionEngine(PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.LocalExecType
 
getExecutionEngine(PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRExecType
 
getExecutionEngine(PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkExecType
 
getExecutionEngine(PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezExecType
 
getExecutionEngine(PigContext) - Method in interface org.apache.pig.ExecType
Returns the Execution Engine that this ExecType is associated with.
getExecutionEngine() - Method in class org.apache.pig.impl.PigContext
 
getExecutionEngineClass() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.LocalExecType
 
getExecutionEngineClass() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRExecType
 
getExecutionEngineClass() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkExecType
 
getExecutionEngineClass() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezExecType
 
getExecutionEngineClass() - Method in interface org.apache.pig.ExecType
Returns the Execution Engine class that this ExecType is associated with.
getExitCode() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.RunJarSecurityManager
 
getExitInvoked() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.RunJarSecurityManager
 
getExponent - Class in org.apache.pig.piggybank.evaluation.math
math.getExponent implements a binding to the Java function Math.getExponent(double).
getExponent() - Constructor for class org.apache.pig.piggybank.evaluation.math.getExponent
 
getExpr() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryExpressionOperator
Get the contained expression.
getExpression() - Method in class org.apache.pig.Expression.UnaryExpression
 
getExpression(LogicalExpression) - Method in class org.apache.pig.newplan.FilterExtractor
 
getExpression(BinaryExpression, Expression.OpType) - Method in class org.apache.pig.newplan.FilterExtractor
 
getExpression(UnaryExpression, Expression.OpType) - Method in class org.apache.pig.newplan.FilterExtractor
 
getExpression() - Method in class org.apache.pig.newplan.logical.expression.UnaryExpression
Get the expression that this unary expression operators on.
getExpression() - Method in exception org.apache.pig.parser.NonProjectExpressionException
 
getExpressionPlans() - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
 
getExpressionPlans() - Method in class org.apache.pig.newplan.logical.relational.LOCube
 
getExpressionPlans() - Method in class org.apache.pig.newplan.logical.relational.LOJoin
Get all of the expressions plans that are in this join.
getExpressionPlanValues() - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
getExpSchemas() - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
getExtraResources() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperPlan
 
getFactor() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezOperDependencyParallelismEstimator.TezParallelismFactorVisitor
 
getFailedJobs() - Method in class org.apache.pig.tools.pigstats.PigStats.JobGraph
 
getFeature() - Method in class org.apache.pig.tools.pigstats.JobStats
 
getFeature() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getFeatures() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
getFeatures() - Method in class org.apache.pig.builtin.AvroStorage
 
getFeatures() - Method in class org.apache.pig.builtin.OrcStorage
 
getFeatures() - Method in class org.apache.pig.builtin.ParquetLoader
 
getFeatures() - Method in class org.apache.pig.builtin.PigStorage
 
getFeatures() - Method in interface org.apache.pig.LoadPushDown
Determine the operators that can be pushed to the loader.
getFeatures() - Method in class org.apache.pig.piggybank.storage.AllLoader
 
getFeatures() - Method in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
getFeatures() - Method in class org.apache.pig.piggybank.storage.CSVLoader
 
getFeatures() - Method in class org.apache.pig.piggybank.storage.FixedWidthLoader
 
getFeatures() - Method in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
getFeatures() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getField(String) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Given an alias name, find the associated FieldSchema.
getField(int) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Given a field number, find the associated FieldSchema.
getField(int) - Method in class org.apache.pig.impl.plan.RequiredFields
 
getField(String) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Fetch a field by alias
getField(int) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Fetch a field by field number
getField(Object, String, int) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
getFieldComment() - Method in class org.apache.pig.impl.util.hive.HiveUtils.Field
 
getFieldDelim() - Method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
getFieldID() - Method in class org.apache.pig.impl.util.hive.HiveUtils.Field
 
getFieldName() - Method in class org.apache.pig.impl.util.hive.HiveUtils.Field
 
getFieldObjectInspector() - Method in class org.apache.pig.impl.util.hive.HiveUtils.Field
 
getFieldPosition(String) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
 
getFields() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
getFields() - Method in class org.apache.pig.impl.plan.RequiredFields
 
getFields() - Method in class org.apache.pig.LoadPushDown.RequiredFieldList
Geta ll required fields as a list.
getFields() - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Get all fields
getFields() - Method in class org.apache.pig.ResourceSchema
Get field schema for each field
getFields() - Method in class org.apache.pig.ResourceStatistics
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.AddExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.AndExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.BinCondExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.CastExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.ConstantExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.DivideExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.EqualExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.GreaterThanEqualExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.GreaterThanExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.IsNullExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.LessThanEqualExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.LessThanExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.LogicalExpression
Get the field schema for the output of this expression operator.
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.MapLookupExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.ModExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.MultiplyExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.NegativeExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.NotEqualExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.NotExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.OrExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.RegexExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.ScalarExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.SubtractExpression
 
getFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
getFieldSubNameMatch(String) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Given an alias name, find the associated FieldSchema.
getFieldSubNameMatch(String) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Given an alias name, find the associated LogicalFieldSchema.
getFile() - Method in class org.apache.pig.parser.PigParserNode.InvocationPoint
 
getFileName() - Method in class org.apache.pig.impl.io.FileSpec
 
getFileName() - Method in class org.apache.pig.parser.PigParserNode
 
getFileName() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
getFileName() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getFileName() - Method in class org.apache.pig.tools.pigstats.ScriptState
 
getFileSpec() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
getFileSpec() - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
getFilteredPlan() - Method in class org.apache.pig.newplan.FilterExtractor
 
getFilterPlan() - Method in class org.apache.pig.newplan.logical.relational.LOFilter
 
getFilterPlan() - Method in class org.apache.pig.newplan.logical.relational.LOSplitOutput
 
getFinal() - Method in interface org.apache.pig.Algebraic
Get the final function.
getFinal() - Method in class org.apache.pig.AlgebraicEvalFunc
This must be implement as per a normal Algebraic interface.
getFinal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getFinal() - Method in class org.apache.pig.builtin.AVG
 
getFinal() - Method in class org.apache.pig.builtin.BigDecimalAvg
 
getFinal() - Method in class org.apache.pig.builtin.BigIntegerAvg
 
getFinal() - Method in class org.apache.pig.builtin.BuildBloom
 
getFinal() - Method in class org.apache.pig.builtin.COR
 
getFinal() - Method in class org.apache.pig.builtin.COUNT
 
getFinal() - Method in class org.apache.pig.builtin.COUNT_STAR
 
getFinal() - Method in class org.apache.pig.builtin.COV
 
getFinal() - Method in class org.apache.pig.builtin.DateTimeMax
 
getFinal() - Method in class org.apache.pig.builtin.DateTimeMin
 
getFinal() - Method in class org.apache.pig.builtin.Distinct
 
getFinal() - Method in class org.apache.pig.builtin.DoubleAvg
 
getFinal() - Method in class org.apache.pig.builtin.FloatAvg
 
getFinal() - Method in class org.apache.pig.builtin.HiveUDAF
 
getFinal() - Method in class org.apache.pig.builtin.IntAvg
 
getFinal() - Method in class org.apache.pig.builtin.LongAvg
 
getFinal() - Method in class org.apache.pig.builtin.StringMax
 
getFinal() - Method in class org.apache.pig.builtin.StringMin
 
getFinal() - Method in class org.apache.pig.builtin.TOP
 
getFinal() - Method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
 
getFinal() - Method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField
 
getFinal() - Method in class org.apache.pig.piggybank.evaluation.stats.COR
Deprecated.
 
getFinal() - Method in class org.apache.pig.piggybank.evaluation.stats.COV
Deprecated.
 
getFinal() - Method in class org.apache.pig.piggybank.evaluation.util.Top
Deprecated.
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.BigDecimalGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.BigIntegerGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.BooleanGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.ChararrayGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.DataBagGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.DataByteArrayGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.DateTimeGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.DoubleGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.FloatGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.IntegerGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.LongGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.MapGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.TupleGroovyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.BagJrubyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.ChararrayJrubyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.DataByteArrayJrubyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.DoubleJrubyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.FloatJrubyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.IntegerJrubyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.LongJrubyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.MapJrubyAlgebraicEvalFunc
 
getFinal() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.TupleJrubyAlgebraicEvalFunc
 
getFirst() - Method in class org.apache.pig.data.utils.StructuresHelper.Pair
 
getFirst() - Method in class org.apache.pig.data.utils.StructuresHelper.Triple
 
getFlatStr() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
getFlattenFlags() - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
getFloat(int) - Method in class org.apache.pig.data.SchemaTuple
 
getFloat(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
getForEach() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.JoinPackager
 
getForEach(POProject, int, String, NodeIdGenerator) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
getForEachInnerLogToPhyMap(LogicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
getForEachPlain(String, NodeIdGenerator) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
getFormatMinSplitSize() - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCInputFormat
The input split size should never be smaller than the RCFile.SYNC_INTERVAL
getFragment() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
getFromCache(PigContext, Configuration, URL) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
getFs() - Method in class org.apache.pig.impl.PigContext
 
getFunc() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getFuncName() - Method in class org.apache.pig.impl.io.FileSpec
 
getFuncSpec() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getFuncSpec() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getFuncSpec() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getFuncSpec() - Method in class org.apache.pig.impl.io.FileSpec
 
getFuncSpec() - Method in class org.apache.pig.newplan.logical.expression.CastExpression
Get the FuncSpec that performs the casting functionality
getFuncSpec() - Method in class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
getFuncSpecFromAlias(String) - Method in class org.apache.pig.impl.PigContext
 
getFunction(String, String) - Static method in class org.apache.pig.scripting.jython.JythonScriptEngine
Gets the Python function object.
getFunctionName() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
getFunctionName() - Method in class org.apache.pig.tools.pigstats.OutputStats
 
getGeneratedCodeFieldType(int) - Method in class org.apache.pig.data.SchemaTuple
 
getGeneratedCodeMemorySize() - Method in class org.apache.pig.data.SchemaTuple
 
getGeneratedInputUids() - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
Returns an Unmodifiable Map of Input Number to Uid
getGenerator() - Static method in class org.apache.pig.impl.plan.NodeIdGenerator
Returns the NodeIdGenerator singleton.
getGrandParentsForGraceParallelism(TezOperPlan, TezOperator) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperPlan
 
getGROp() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POJoinGroupSpark
 
getGroupDisplayName() - Method in class org.apache.pig.tools.pigstats.spark.SparkCounterGroup
 
getGroupName() - Method in class org.apache.pig.tools.pigstats.spark.SparkCounterGroup
 
getGroupType() - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
 
getHadoopCounters() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getHadoopCounters() instead.
getHadoopCounters() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getHadoopCounters() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getHadoopCounters() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getHadoopCounters() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getHadoopVersion() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getHadoopVersion() - Method in class org.apache.pig.tools.pigstats.ScriptState
 
getHandleSpecs(StreamingCommand.Handle) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get specifications for the given Handle.
getHashCode() - Method in class org.apache.pig.impl.util.HashOutputStream
 
getHdfsBytesRead() - Method in class org.apache.pig.tools.pigstats.JobStats
 
getHdfsBytesWritten() - Method in class org.apache.pig.tools.pigstats.JobStats
 
getHelpMessage() - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
getHFS() - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
getHFS() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
GetHour - Class in org.apache.pig.builtin
GetHour extracts the hour of a day from a DateTime object.
GetHour() - Constructor for class org.apache.pig.builtin.GetHour
 
getId() - Method in class org.apache.pig.impl.plan.OperatorKey
 
getId() - Method in class org.apache.pig.tools.pigstats.ScriptState
 
getIdxFuncSpec() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
getIllustrator() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getIllustrator() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getIllustratorContext(Configuration, DataBag, List<Pair<PigNullableWritable, Writable>>, InputSplit) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
 
getIllustratorContext(Job, List<Pair<PigNullableWritable, Writable>>, POPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
Get reducer's illustrator context
getIllustratorContext(Configuration, DataBag, List<Pair<PigNullableWritable, Writable>>, InputSplit) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
Get mapper's illustrator context
getIllustratorContext(Job, List<Pair<PigNullableWritable, Writable>>, POPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
Get reducer's illustrator context
getImplicitReferencedOperator() - Method in class org.apache.pig.newplan.logical.expression.ScalarExpression
 
getIndex() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
getIndex() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getIndex() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.IndexedKey
 
getIndex() - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
getIndex() - Method in class org.apache.pig.impl.io.PigNullableWritable
 
getIndex(E) - Method in class org.apache.pig.impl.plan.OperatorPlan.IndexHelper
 
getIndex() - Method in class org.apache.pig.LoadPushDown.RequiredField
 
getIndexFile() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
getIndexFileName() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
getIndexKeyTuple(Tuple) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Extracts the index key from the index tuple
getIndexKeyTupleCount(Tuple) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Extracts the number of records that share the current key from the index tuple.
getInitial() - Method in interface org.apache.pig.Algebraic
Get the initial function.
getInitial() - Method in class org.apache.pig.AlgebraicEvalFunc
This must be implement as per a normal Algebraic interface.
getInitial() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getInitial() - Method in class org.apache.pig.builtin.AlgebraicByteArrayMathBase
 
getInitial() - Method in class org.apache.pig.builtin.AVG
 
getInitial() - Method in class org.apache.pig.builtin.BigDecimalAvg
 
getInitial() - Method in class org.apache.pig.builtin.BigIntegerAvg
 
getInitial() - Method in class org.apache.pig.builtin.BuildBloom
 
getInitial() - Method in class org.apache.pig.builtin.COR
 
getInitial() - Method in class org.apache.pig.builtin.COUNT
 
getInitial() - Method in class org.apache.pig.builtin.COUNT_STAR
 
getInitial() - Method in class org.apache.pig.builtin.COV
 
getInitial() - Method in class org.apache.pig.builtin.DateTimeMax
 
getInitial() - Method in class org.apache.pig.builtin.DateTimeMin
 
getInitial() - Method in class org.apache.pig.builtin.Distinct
 
getInitial() - Method in class org.apache.pig.builtin.DoubleAvg
 
getInitial() - Method in class org.apache.pig.builtin.FloatAvg
 
getInitial() - Method in class org.apache.pig.builtin.HiveUDAF
 
getInitial() - Method in class org.apache.pig.builtin.IntAvg
 
getInitial() - Method in class org.apache.pig.builtin.LongAvg
 
getInitial() - Method in class org.apache.pig.builtin.StringMax
 
getInitial() - Method in class org.apache.pig.builtin.StringMin
 
getInitial() - Method in class org.apache.pig.builtin.TOP
 
getInitial() - Method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
Algebraic interface
getInitial() - Method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField
 
getInitial() - Method in class org.apache.pig.piggybank.evaluation.stats.COR
Deprecated.
 
getInitial() - Method in class org.apache.pig.piggybank.evaluation.stats.COV
Deprecated.
 
getInitial() - Method in class org.apache.pig.piggybank.evaluation.util.Top
Deprecated.
 
getInitial() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc
 
getInitial() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc
 
getInitialized() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
getInner() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.LitePackager
 
getInner() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getInner() - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
 
getInnerFlags() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
getInnerFlags() - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
getInnerPlan() - Method in class org.apache.pig.newplan.logical.relational.LOForEach
 
getInnerPlansOf(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
getInp() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.LoaderInfo
 
getInpLimits() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.LoaderInfo
 
getInpSignatureLists() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.LoaderInfo
 
getInput(LogicalPlan) - Method in class org.apache.pig.newplan.logical.relational.LODistinct
 
getInput(LogicalPlan) - Method in class org.apache.pig.newplan.logical.relational.LOFilter
 
getInput(LogicalPlan) - Method in class org.apache.pig.newplan.logical.relational.LOLimit
 
getInput(LogicalPlan) - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
getInputArgsSchema() - Method in class org.apache.pig.FuncSpec
 
getInputAvroSchema() - Method in class org.apache.pig.builtin.AvroStorage
Helper function reads the input avro schema from the UDF Properties.
getInputColumn() - Method in class org.apache.pig.impl.plan.ProjectionMap.Column
Get the mapped column details
getInputFormat() - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
getInputFormat() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MergeJoinIndexer
 
getInputFormat() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
getInputFormat() - Method in class org.apache.pig.builtin.AvroStorage
 
getInputFormat() - Method in class org.apache.pig.builtin.BinStorage
 
getInputFormat() - Method in class org.apache.pig.builtin.JsonLoader
 
getInputFormat() - Method in class org.apache.pig.builtin.mock.Storage
 
getInputFormat() - Method in class org.apache.pig.builtin.OrcStorage
 
getInputFormat() - Method in class org.apache.pig.builtin.PigStorage
 
getInputFormat() - Method in class org.apache.pig.builtin.TextLoader
 
getInputFormat() - Method in class org.apache.pig.builtin.TrevniStorage
 
getInputFormat() - Method in class org.apache.pig.impl.builtin.DefaultIndexableLoader
 
getInputFormat() - Method in class org.apache.pig.impl.builtin.SampleLoader
 
getInputFormat() - Method in class org.apache.pig.impl.io.InterStorage
 
getInputFormat() - Method in class org.apache.pig.impl.io.ReadToEndLoader
 
getInputFormat() - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
getInputFormat() - Method in class org.apache.pig.impl.io.TFileStorage
 
getInputFormat() - Method in class org.apache.pig.LoadFunc
This will be called during planning on the front end.
getInputFormat() - Method in class org.apache.pig.LoadFuncWrapper
 
getInputFormat() - Method in class org.apache.pig.piggybank.storage.AllLoader
 
getInputFormat() - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
getInputFormat() - Method in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
getInputFormat() - Method in class org.apache.pig.piggybank.storage.CSVLoader
 
getInputFormat() - Method in class org.apache.pig.piggybank.storage.FixedWidthLoader
 
getInputFormat() - Method in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
getInputFormat() - Method in class org.apache.pig.piggybank.storage.IndexedStorage
 
getInputFormat() - Method in class org.apache.pig.piggybank.storage.RegExLoader
 
getInputFormat() - Method in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
getInputFormat() - Method in class org.apache.pig.piggybank.storage.XMLLoader
 
getInputFormatEntries(Configuration) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
getInputKeys() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POFRJoinTez
 
getInputNum() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
Input number this project references.
getInputPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.JoinPackager
 
getInputPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
getInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
getInputs(LogicalPlan) - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
 
getInputs() - Method in class org.apache.pig.newplan.logical.relational.LOCross
 
getInputs(LogicalPlan) - Method in class org.apache.pig.newplan.logical.relational.LOCube
 
getInputs(LogicalPlan) - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
getInputs() - Method in class org.apache.pig.newplan.logical.relational.LOUnion
 
getInputs(LogicalPlan) - Method in class org.apache.pig.newplan.logical.relational.LOUnion
 
getInputs() - Method in class org.apache.pig.pen.Illustrator
 
getInputs() - Method in class org.apache.pig.tools.pigstats.JobStats
 
getInputSchema() - Method in class org.apache.pig.EvalFunc
This method is intended to be called by the user in EvalFunc to get the input schema of the EvalFunc
getInputSpec() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getInputSpec() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get the input specification of the StreamingCommand.
getInputSpec() - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
getInputSplitInfo() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.LoaderInfo
 
getInputStats() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getInputStats() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getInputType() - Method in class org.apache.pig.impl.streaming.DefaultInputHandler
 
getInputType() - Method in class org.apache.pig.impl.streaming.FileInputHandler
 
getInputType() - Method in class org.apache.pig.impl.streaming.InputHandler
Get the handled InputType
getInputType() - Method in class org.apache.pig.tools.pigstats.InputStats
 
getInputTypeClass() - Method in class org.apache.pig.PrimitiveEvalFunc
 
getInputUids(long) - Method in class org.apache.pig.newplan.logical.relational.LOSplitOutput
 
getInputUids(long) - Method in class org.apache.pig.newplan.logical.relational.LOUnion
 
getInstance() - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigHadoopLogger
Get singleton instance of the context
getInstance() - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.ObjectCache
 
getInstance() - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.TezResourceManager
 
getInstance() - Static method in class org.apache.pig.backend.hadoop.PigATSClient
 
getInstance() - Static method in class org.apache.pig.data.BagFactory
Get a reference to the singleton factory.
getInstance(int) - Static method in class org.apache.pig.data.SchemaTupleFactory
This method is the publicly facing method which returns a SchemaTupleFactory which will generate the SchemaTuple associated with the given identifier.
getInstance(Schema, boolean, SchemaTupleClassGenerator.GenContext) - Static method in class org.apache.pig.data.SchemaTupleFactory
This method is the publicly facing method which returns a SchemaTupleFactory which will generate SchemaTuples of the given Schema.
getInstance(Schema, boolean) - Static method in class org.apache.pig.data.SchemaTupleFactory
 
getInstance(Schema) - Static method in class org.apache.pig.data.SchemaTupleFactory
 
getInstance() - Static method in class org.apache.pig.data.TupleFactory
Get a reference to the singleton factory.
getInstance() - Static method in class org.apache.pig.impl.util.SpillableMemoryManager
 
getInstance() - Static method in class org.apache.pig.JVMReuseManager
 
getInstance() - Static method in class org.apache.pig.scripting.js.JsScriptEngine
 
getInstance(String) - Static method in class org.apache.pig.scripting.ScriptEngine
Gets instance of the scriptEngine for the given scripting language
getInstance() - Static method in class org.apache.pig.tools.DownloadResolver
 
getInstance() - Static method in class org.apache.pig.tools.pigstats.PigStatusReporter
Get singleton instance of the context
getInstance() - Static method in class org.apache.pig.tools.pigstats.spark.SparkPigStatusReporter
 
getInt(CommandLine, Option) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
getInt(int) - Method in class org.apache.pig.data.SchemaTuple
 
getInt(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
getIntermed() - Method in interface org.apache.pig.Algebraic
Get the intermediate function.
getIntermed() - Method in class org.apache.pig.AlgebraicEvalFunc
This must be implement as per a normal Algebraic interface.
getIntermed() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getIntermed() - Method in class org.apache.pig.builtin.AVG
 
getIntermed() - Method in class org.apache.pig.builtin.BigDecimalAvg
 
getIntermed() - Method in class org.apache.pig.builtin.BigIntegerAvg
 
getIntermed() - Method in class org.apache.pig.builtin.BuildBloom
 
getIntermed() - Method in class org.apache.pig.builtin.COR
 
getIntermed() - Method in class org.apache.pig.builtin.COUNT
 
getIntermed() - Method in class org.apache.pig.builtin.COUNT_STAR
 
getIntermed() - Method in class org.apache.pig.builtin.COV
 
getIntermed() - Method in class org.apache.pig.builtin.DateTimeMax
 
getIntermed() - Method in class org.apache.pig.builtin.DateTimeMin
 
getIntermed() - Method in class org.apache.pig.builtin.Distinct
 
getIntermed() - Method in class org.apache.pig.builtin.DoubleAvg
 
getIntermed() - Method in class org.apache.pig.builtin.FloatAvg
 
getIntermed() - Method in class org.apache.pig.builtin.HiveUDAF
 
getIntermed() - Method in class org.apache.pig.builtin.IntAvg
 
getIntermed() - Method in class org.apache.pig.builtin.LongAvg
 
getIntermed() - Method in class org.apache.pig.builtin.StringMax
 
getIntermed() - Method in class org.apache.pig.builtin.StringMin
 
getIntermed() - Method in class org.apache.pig.builtin.TOP
 
getIntermed() - Method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
 
getIntermed() - Method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField
 
getIntermed() - Method in class org.apache.pig.piggybank.evaluation.stats.COR
Deprecated.
 
getIntermed() - Method in class org.apache.pig.piggybank.evaluation.stats.COV
Deprecated.
 
getIntermed() - Method in class org.apache.pig.piggybank.evaluation.util.Top
Deprecated.
 
getIntermed() - Method in class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc
 
getIntermed() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc
 
getIntermediate() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.MRIntermediateDataVisitor
Get all paths for intermediate data.
getIntermediateOutputKeyClass() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
getIntermediateOutputKeyComparatorClass() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
getIntermediateOutputValueClass() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
getInternalSchema() - Method in class org.apache.pig.scripting.jruby.RubySchema
This is a helper method to pull out the native Java type from the ruby object.
getInterSedesInstance() - Static method in class org.apache.pig.data.InterSedesFactory
 
getInvocationStack() - Method in class org.apache.pig.parser.PigParserNode
 
getInvocationTarget() - Method in class org.apache.pig.scripting.groovy.GroovyEvalFunc
 
getIsKeyWrappedList() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
Returns the list of booleans that indicates if the key needs to unwrapped for the corresponding plan.
getJarPath(Class<?>) - Static method in class org.apache.pig.scripting.ScriptEngine
Figures out the jar location from the class
getJobClient() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getJobClient() - Method in class org.apache.pig.tools.pigstats.mapreduce.SimplePigStats
Deprecated.
getJobClient() - Method in class org.apache.pig.tools.pigstats.PigStats
Deprecated.
getJobClient() - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
getJobClient() - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
getJobConf() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
Deprecated.
getJobConf() - Method in class org.apache.pig.impl.util.UDFContext
Get the JobConf.
getJobGraph() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getJobGraph() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the DAG of jobs spawned by the script
getJobId() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.NativeMapReduceOper
 
getJobId() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.NativeSparkOperator
 
getJobId() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.NativeTezOper
 
getJobId() - Method in class org.apache.pig.tools.pigstats.JobStats
 
getJobId() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getJobId() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getJobId() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
getJobId() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
getJobList() - Method in class org.apache.pig.tools.pigstats.PigStats.JobGraph
Returns a List representation of the Job graph.
getJobMetric(int) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
getJobMroMap() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
Gets the map of Job and the MR Operator
getJobName() - Method in class org.apache.pig.PigServer
 
getJobNumber() - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.NativeMapReduceOper
 
getJobPriority() - Method in class org.apache.pig.PigServer
 
getJobs(PigStats) - Method in class org.apache.pig.PigServer
Retrieves a list of Job objects from the PigStats object
getJoinPlan(int) - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
getJoinPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
getJoinPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
getJoinType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
getJoinType() - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
getKey(PigNullableWritable) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getKey() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getKey() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.IndexedKey
 
getKey() - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
getKey() - Method in class org.apache.pig.pen.FakeRawKeyValueIterator
 
getKeyAsTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getKeyFromResult(List<Result>, byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
getKeyInfo() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getKeyPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
getKeys() - Method in class org.apache.pig.impl.plan.MapKeysInfo
 
getKeys() - Method in class org.apache.pig.impl.plan.OperatorPlan
Get the map of operator key and associated operators
getKeyTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getKeyType() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
 
getKeyType() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
 
getKeyType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getKeyType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
getKeyType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
getKeyType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
getKind() - Method in class org.apache.pig.impl.plan.CompilationMessageCollector.Message
 
getKindAggregate(CompilationMessageCollector.MessageType) - Method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
getLanguage() - Method in exception org.apache.pig.impl.streaming.StreamingUDFException
 
getLast(Path, FileSystem) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
get last file of a hdfs path if it is a directory; or return the file itself if path is a file
getLastAlias() - Method in class org.apache.pig.impl.PigContext
 
getLastRel(SourceLocation) - Method in class org.apache.pig.parser.LogicalPlanBuilder
 
getLastRel() - Method in class org.apache.pig.parser.LogicalPlanBuilder
 
getLastRel() - Method in class org.apache.pig.parser.QueryParserDriver
 
getLastRel() - Method in class org.apache.pig.PigServer
 
getLastRel() - Method in class org.apache.pig.PigServer.Graph
 
getLeaves() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
getLeaves() - Method in class org.apache.pig.impl.plan.OperatorPlan
Get a list of all nodes in the graph that are leaves.
getLength() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getLength(int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
Return the length of a wrapped split
getLength() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
getLength(int) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
getLength() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
getLength(int) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
getLength(int) - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit
 
getLength() - Method in class org.apache.pig.data.WritableByteArray
Returns the length of the valid data currently in the buffer
getLFile() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
getLfs() - Method in class org.apache.pig.impl.PigContext
 
getLhs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
getLhs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
Get left expression
getLhs() - Method in class org.apache.pig.Expression.BinaryExpression
 
getLhs() - Method in class org.apache.pig.newplan.logical.expression.BinaryExpression
Get the left hand side of this binary expression.
getLhs() - Method in class org.apache.pig.newplan.logical.expression.BinCondExpression
Get the left hand side of this expression.
getLimit() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
getLimit() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
getLimit() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
getLimit() - Method in class org.apache.pig.newplan.logical.relational.LOLimit
 
getLimit() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
getLimit() - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
getLimitPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
getLimitPlan() - Method in class org.apache.pig.newplan.logical.relational.LOLimit
 
getLine() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator.OriginalLocation
 
getLine() - Method in class org.apache.pig.parser.PigParserNode.InvocationPoint
 
getLineage() - Method in class org.apache.pig.pen.ExampleGenerator
 
getLineage() - Method in class org.apache.pig.pen.Illustrator
 
getLineNumber() - Method in exception org.apache.pig.impl.streaming.StreamingUDFException
 
getLineNumber() - Method in exception org.apache.pig.impl.streaming.StreamingUDFOutputSchemaException
 
getLineNumber() - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
Get the line number in the submitted Pig Latin script where this operator occurred.
getLoadCaster() - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
getLoadCaster() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MergeJoinIndexer
 
getLoadCaster() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
Set up the caster to use for reading values out of, and writing to, HBase.
getLoadCaster() - Method in class org.apache.pig.builtin.BinStorage
 
getLoadCaster() - Method in class org.apache.pig.builtin.JsonLoader
 
getLoadCaster() - Method in class org.apache.pig.builtin.mock.Storage
 
getLoadCaster() - Method in class org.apache.pig.builtin.PigStreaming
 
getLoadCaster() - Method in class org.apache.pig.builtin.TextLoader
 
getLoadCaster() - Method in class org.apache.pig.EvalFunc
This will be called on both the front end and the back end during execution.
getLoadCaster() - Method in class org.apache.pig.impl.builtin.DefaultIndexableLoader
 
getLoadCaster() - Method in class org.apache.pig.impl.builtin.SampleLoader
 
getLoadCaster() - Method in class org.apache.pig.impl.io.ReadToEndLoader
 
getLoadCaster() - Method in class org.apache.pig.impl.streaming.PigStreamingUDF
 
getLoadCaster() - Method in class org.apache.pig.LoadFunc
This will be called on both the front end and the back end during execution.
getLoadCaster() - Method in class org.apache.pig.LoadFuncWrapper
 
getLoadCaster() - Method in class org.apache.pig.piggybank.storage.AllLoader
 
getLoadCaster() - Method in class org.apache.pig.PigStreamingBase
This will be called on the front end during planning and not on the back end during execution.
getLoadCaster() - Method in interface org.apache.pig.StreamToPig
Deprecated.
This will be called on both the front end and the back end during execution.
getLoaderInfo() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getLoadFunc() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
getLoadFunc() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
getLoadFuncs() - Method in class org.apache.pig.newplan.logical.relational.LogicalPlanData
 
getLoads() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.LoaderInfo
 
getLocalConf() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
getLocalCounter() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
getLocalFSProperties() - Static method in class org.apache.pig.backend.hadoop.datastorage.ConfigurationUtil
 
getLocalRearrangePlanFromSplit(PhysicalPlan, OperatorKey) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.PlanHelper
Finds POLocalRearrange from POSplit sub-plan
getLocalResources() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainer
 
getLocation() - Method in class org.apache.pig.newplan.Operator
 
getLocation() - Method in class org.apache.pig.tools.pigstats.InputStats
 
getLocation() - Method in class org.apache.pig.tools.pigstats.OutputStats
 
getLocationInfo() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getLocationInfo() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
getLocationInfo() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
getLocationInfo() - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit
 
getLocations() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getLocations() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
getLocations() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
getLOForEach() - Method in class org.apache.pig.newplan.logical.relational.LOInnerLoad
Get the LOForEach operator that contains this operator as part of inner plan
getLog4jProperties() - Method in class org.apache.pig.impl.PigContext
 
getLogDir() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get the directory where the log-files of the command are persisted.
getLogFilesLimit() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get the maximum number of tasks whose stderr logs files are persisted.
getLogger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getLogger() - Method in class org.apache.pig.EvalFunc
 
getLogicalPlan() - Method in class org.apache.pig.PigServer.Graph
 
getLogicalPlanData() - Method in class org.apache.pig.PigServer
Returns data associated with LogicalPlan.
getLogicalRelationalOperators(LogicalPlan, Class<C>) - Static method in class org.apache.pig.newplan.logical.Util
Returns a LinkedList of operators contained within the physical plan which implement the supplied class, in dependency order.
getLogs(OutputStream) - Method in interface org.apache.pig.backend.executionengine.ExecJob
Collecting various forms of outputs
getLogs(OutputStream) - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getLogToPhyMap() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
getLogToPhyMap() - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
getLogToPhyMap() - Method in class org.apache.pig.pen.ExampleGenerator
 
getLong(CommandLine, Option) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
getLong(int) - Method in class org.apache.pig.data.SchemaTuple
 
getLong(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
getLookUpKey() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getLookupKey() - Method in class org.apache.pig.newplan.logical.expression.MapLookupExpression
 
getLoRearrangeFound() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOPackageAnnotator.LoRearrangeDiscoverer
 
getLoToEqClassMap(PhysicalPlan, LogicalPlan, Map<Operator, PhysicalOperator>, Map<Operator, DataBag>, Map<LOForEach, Map<LogicalRelationalOperator, PhysicalOperator>>, HashMap<PhysicalOperator, Collection<IdentityHashSet<Tuple>>>) - Static method in class org.apache.pig.pen.EquivalenceClasses
 
getLoToEqClassMap() - Method in class org.apache.pig.pen.ExampleGenerator
 
getLower() - Method in class org.apache.pig.Expression.BetweenExpression
 
getLRInnerPlansOf(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
getLROp() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
getLROps() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POJoinGroupSpark
 
getLRs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
getLRs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
getMacro() - Method in class org.apache.pig.parser.PigParserNode.InvocationPoint
 
getMainKeyType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
getMajorVersion() - Static method in class org.apache.pig.Main
Returns the major version of Pig being run.
getManifest(Class<T>) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkUtil
 
getMap(int) - Method in class org.apache.pig.data.SchemaTuple
 
getMap(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
getMap() - Method in class org.apache.pig.newplan.logical.expression.MapLookupExpression
 
getMapBegin() - Method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
getMapEnd() - Method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
getMapEntrySize(Object, Object) - Static method in class org.apache.pig.data.SizeUtil
 
getMapInputRecords() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getMapInputRecords() instead.
getMapInputRecords() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getMapInputRecords() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getMapInputRecords() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getMapInputRecords() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getMapKeyDelim() - Method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
getMapKeysInfo(int) - Method in class org.apache.pig.impl.plan.RequiredFields
Get the ith MapKeysInfo structure
getMapOutputRecords() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getMapOutputRecords() instead.
getMapOutputRecords() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getMapOutputRecords() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getMapOutputRecords() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getMapOutputRecords() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getMappedFields() - Method in class org.apache.pig.impl.plan.ProjectionMap
 
getMappedKeys(String[]) - Method in class org.apache.pig.newplan.logical.rules.PartitionFilterOptimizer.PartitionFilterPushDownTransformer
The partition keys in the argument are as reported by LoadMetadata#getPartitionKeys(String, org.apache.hadoop.conf.Configuration).
getMarkedAsShowToUser() - Method in exception org.apache.pig.PigException
Check if this PigException is marked as the ones whose message is to be displayed to the user.
getMAscCols() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
getMatch() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternNode
 
getMaxMapTime() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getMaxMapTime() instead.
getMaxMapTime() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getMaxMapTime() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getMaxMapTime() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getMaxMapTime() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getMaxReduceTime() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getMaxReduceTime() instead.
getMaxReduceTime() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getMaxReduceTime() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getMaxReduceTime() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getMaxReduceTime() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getmBytes() - Method in class org.apache.pig.ResourceStatistics
 
getMComparator() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
getMembers(Tuple) - Method in class org.apache.pig.impl.util.LineageTracer
 
getMembers(Tuple) - Method in class org.apache.pig.pen.util.LineageTracer
 
getMembershipMap() - Method in class org.apache.pig.impl.util.LineageTracer
 
getMembershipMap() - Method in class org.apache.pig.pen.util.LineageTracer
 
GetMemNumRows - Class in org.apache.pig.impl.builtin
UDF to get memory size of a tuple and extracts number of rows value from special tuple created by PoissonSampleLoader It is used by skewed join.
GetMemNumRows() - Constructor for class org.apache.pig.impl.builtin.GetMemNumRows
 
getMemorySize() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
getMemorySize(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.FindQuantilesTez
 
getMemorySize() - Method in class org.apache.pig.data.AccumulativeBag
 
getMemorySize() - Method in class org.apache.pig.data.AppendableSchemaTuple
This adds the additional overhead of the append Tuple
getMemorySize() - Method in class org.apache.pig.data.DefaultAbstractBag
Return the size of memory usage.
getMemorySize() - Method in class org.apache.pig.data.DefaultTuple
Determine the size of tuple in memory.
getMemorySize() - Method in class org.apache.pig.data.LimitedSortedDataBag
Not implemented.
getMemorySize() - Method in class org.apache.pig.data.NonSpillableDataBag
 
getMemorySize() - Method in class org.apache.pig.data.ReadOnceBag
 
getMemorySize() - Method in class org.apache.pig.data.SchemaTuple
This only accounts for the size of members (adjusting for word alignment).
getMemorySize() - Method in class org.apache.pig.data.SingleTupleBag
 
getMemorySize() - Method in class org.apache.pig.data.TargetedTuple
 
getMemorySize() - Method in interface org.apache.pig.data.Tuple
Determine the size of tuple in memory.
getMemorySize() - Method in class org.apache.pig.data.UnlimitedNullTuple
 
getMemorySize(Tuple) - Method in class org.apache.pig.impl.builtin.PartitionSkewedKeys
 
getMemorySize() - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
getMemorySize() - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
getMemorySize() - Method in interface org.apache.pig.impl.util.Spillable
Requests that an object return an estimate of its in memory size.
getMemorySize() - Method in class org.apache.pig.pen.util.ExampleTuple
 
getMergedSchema(Set<Path>, Configuration) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
Merge multiple input avro schemas into one.
getMessage() - Method in class org.apache.pig.impl.plan.CompilationMessageCollector.Message
 
getMessage() - Method in exception org.apache.pig.impl.streaming.StreamingUDFException
 
getMessage() - Method in exception org.apache.pig.tools.parameters.ParameterSubstitutionException
 
getMessageCollector() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.CombinerOptimizer
 
getMessageCollector() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
getMessageCollector() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.CombinerOptimizer
 
getMessageType() - Method in class org.apache.pig.impl.plan.CompilationMessageCollector.Message
 
getMethodName(int) - Method in class org.apache.pig.LoadFuncWrapper
Returns a method in the call stack at the given depth.
getMethodName(int) - Method in class org.apache.pig.StoreFuncWrapper
Returns a method in the call stack at the given depth.
GetMilliSecond - Class in org.apache.pig.builtin
GetSecond extracts the millisecond of a second from a DateTime object.
GetMilliSecond() - Constructor for class org.apache.pig.builtin.GetMilliSecond
 
getMinMapTime() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getMinMapTime() instead.
getMinMapTime() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getMinMapTime() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getMinMapTime() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getMinMapTime() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getMinorVersion() - Static method in class org.apache.pig.Main
Returns the major version of the Pig build being run.
getMinReduceTime() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getMinReduceTime() instead.
getMinReduceTime() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getMinReduceTime() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getMinReduceTime() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getMinReduceTime() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
GetMinute - Class in org.apache.pig.builtin
GetMinute extracts the minute of an hour from a DateTime object.
GetMinute() - Constructor for class org.apache.pig.builtin.GetMinute
 
GetMonth - Class in org.apache.pig.builtin
GetMonth extracts the month of a year from a DateTime object.
GetMonth() - Constructor for class org.apache.pig.builtin.GetMonth
 
getMostCommonValues() - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
getMostCommonValuesFreq() - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
getMRPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
Used to get the compiled plan
getMSortFunc() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
getMultiInputCounters() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getMultiInputCounters() instead.
getMultiInputCounters() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getMultiInputCounters() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getMultiInputCounters() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getMultiInputCounters() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getMultiInputNestedPlans(E) - Method in class org.apache.pig.impl.plan.PlanDumper
Used to determine if an operator has nested plans, which are connected to specific input operators.
getMultiInputNestedPlans(Operator) - Method in class org.apache.pig.newplan.logical.DotLOPrinter
 
getMultiInputNestedPlans(Operator) - Method in class org.apache.pig.newplan.PlanDumper
Used to determine if an operator has nested plans, which are connected to specific input operators.
getMultiInputsCounterName(String, int) - Static method in class org.apache.pig.tools.pigstats.PigStatsUtil
Returns the counter name for the given input file name
getMultiOutputNestedPlans(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.DotPOPrinter
 
getMultiOutputNestedPlans(E) - Method in class org.apache.pig.impl.plan.PlanDumper
Used to determine if an operator has nested output plans
getMultiOutputNestedPlans(Operator) - Method in class org.apache.pig.newplan.PlanDumper
Used to determine if an operator has nested output plans
getMultiQueryOptimizeConnectionItem() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
getMultiStoreCount(Job, JobClient, String) - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
Returns the count for the given counter name in the counter group 'MultiStoreCounters'
getMultiStoreCounterName(POStore) - Static method in class org.apache.pig.tools.pigstats.PigStatsUtil
Returns the counter name for the given POStore
getMultiStoreCounters() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getMultiStoreCounters() instead.
getMultiStoreCounters() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getMultiStoreCounters() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getMultiStoreCounters() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getMultiStoreCounters() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getMutations(Tuple) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
getMutations(Tuple) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorage
 
getName(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter
 
getName(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.DotPOPrinter
 
getName(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter
 
getName() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
getName() - Method in class org.apache.pig.Expression.Column
 
getName(E) - Method in class org.apache.pig.impl.plan.DotPlanDumper
Used to generate the label for an operator.
getName() - Method in class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
Get the name of the HandleSpec.
getName(Operator) - Method in class org.apache.pig.newplan.DotPlanDumper
Used to generate the label for an operator.
getName(Operator) - Method in class org.apache.pig.newplan.logical.DotLOPrinter
 
getName() - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
getName() - Method in class org.apache.pig.newplan.Operator
 
getName() - Method in class org.apache.pig.newplan.optimizer.Rule
 
getName() - Method in class org.apache.pig.ResourceSchema.ResourceFieldSchema
Get the name of this field.
getName(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubySchema
This method allows the user to see the name of the alias of the FieldSchema of the encapsulated Schema.
getName() - Method in class org.apache.pig.tools.pigstats.InputStats
 
getName() - Method in class org.apache.pig.tools.pigstats.OutputStats
 
getName() - Method in class org.apache.pig.tools.pigstats.spark.SparkCounter
 
getNativeMRjar() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PONative
 
getNativeMRJar() - Method in class org.apache.pig.newplan.logical.relational.LONative
 
getNeedAllFields() - Method in class org.apache.pig.impl.plan.RequiredFields
 
getNeedNoFields() - Method in class org.apache.pig.impl.plan.RequiredFields
 
getNestedPlans(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter
 
getNestedPlans(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.DotPOPrinter
 
getNestedPlans(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter
 
getNestedPlans(E) - Method in class org.apache.pig.impl.plan.PlanDumper
Used to determine if an operator has nested plans (without connections to in- or output operators.
getNestedPlans(Operator) - Method in class org.apache.pig.newplan.logical.DotLOPrinter
 
getNestedPlans(Operator) - Method in class org.apache.pig.newplan.PlanDumper
Used to determine if an operator has nested plans (without connections to in- or output operators.
getNewBaseData() - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
getNewName() - Static method in class org.apache.pig.impl.logicalLayer.CanonicalNamer
 
getNewRearrange(POLocalRearrange) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil
create new Local rearrange by cloning existing rearrange and add plan for projecting the key
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.AddForEach
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.ColumnMapKeyPrune
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.ConstantCalculator
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.FilterAboveForeach
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.GroupByConstParallelSetter
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.LimitOptimizer
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.MergeFilter
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.MergeForEach
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.NestedLimitOptimizer
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.PartitionFilterOptimizer
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.PredicatePushdownOptimizer
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.PushDownForEachFlatten
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.PushUpFilter
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.SplitFilter
 
getNewTransformer() - Method in class org.apache.pig.newplan.logical.rules.TypeCastInserter
 
getNewTransformer() - Method in class org.apache.pig.newplan.optimizer.Rule
Get the transformer for this rule.
getNewWritableComparable(byte) - Static method in class org.apache.pig.backend.hadoop.HDataType
 
getNext() - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
getNext() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MergeJoinIndexer
 
getNext() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.DiscreteProbabilitySampleGenerator
 
getNext() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
Fetches the input tuple and returns the requested column
getNext(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
Implementations that call into the different versions of getNext are often identical, differing only in the signature of the getNext() call they make.
getNext() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.CombinerPackager
 
getNext() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.JoinPackager
Calls getNext to get next ForEach result.
getNext() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.LitePackager
Similar to POPackage.getNext except that only one input is expected with index 0 and ReadOnceBag is used instead of DefaultDataBag.
getNext() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
Constructs the output tuple from the inputs.
getNext() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getNext() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.BloomPackager
 
getNext() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
getNext() - Method in class org.apache.pig.builtin.AvroStorage
 
getNext() - Method in class org.apache.pig.builtin.BinStorage
 
getNext() - Method in class org.apache.pig.builtin.JsonLoader
 
getNext() - Method in class org.apache.pig.builtin.mock.Storage
 
getNext() - Method in class org.apache.pig.builtin.OrcStorage
 
getNext() - Method in class org.apache.pig.builtin.PigStorage
 
getNext() - Method in class org.apache.pig.builtin.TextLoader
 
getNext() - Method in class org.apache.pig.impl.builtin.DefaultIndexableLoader
 
getNext() - Method in class org.apache.pig.impl.builtin.PoissonSampleLoader
 
getNext() - Method in class org.apache.pig.impl.builtin.RandomSampleLoader
Allocate a buffer for numSamples elements, populate it with the first numSamples tuples, and continue scanning rest of the input.
getNext() - Method in class org.apache.pig.impl.io.InterStorage
 
getNext() - Method in class org.apache.pig.impl.io.ReadToEndLoader
 
getNext() - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
getNext() - Method in class org.apache.pig.impl.io.TFileStorage
 
getNext() - Method in class org.apache.pig.impl.streaming.OutputHandler
Get the next output Tuple of the managed process.
getNext() - Method in class org.apache.pig.LoadFunc
Retrieves the next tuple to be processed.
getNext() - Method in class org.apache.pig.LoadFuncWrapper
 
getNext() - Method in class org.apache.pig.piggybank.storage.AllLoader
 
getNext() - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
getNext() - Method in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
getNext() - Method in class org.apache.pig.piggybank.storage.CSVLoader
 
getNext() - Method in class org.apache.pig.piggybank.storage.FixedWidthLoader
 
getNext() - Method in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
getNext() - Method in class org.apache.pig.piggybank.storage.IndexedStorage
 
getNext() - Method in class org.apache.pig.piggybank.storage.RegExLoader
 
getNext() - Method in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
getNext() - Method in class org.apache.pig.piggybank.storage.XMLLoader
 
getNextBigDecimal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
getNextBigDecimal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextBigDecimal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
getNextBigDecimal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
getNextBigDecimal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextBigDecimal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextBigDecimal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
getNextBigDecimal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNextBigDecimal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextBigDecimal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextBigDecimal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
getNextBigDecimal() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Mod
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
getNextBigInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextBoolean() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.EqualToExpr
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GreaterThanExpr
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GTOrEqualToExpr
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LessThanExpr
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LTOrEqualToExpr
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.NotEqualToExpr
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POAnd
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POIsNull
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONot
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POOr
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORegexp
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextBoolean() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextDataBag() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNextDataBag() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextDataBag() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
 
getNextDataBag() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextDataBag() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextDataBag() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNextDataBag() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNextDataBag() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORelationToExprProject
 
getNextDataBag() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextDataBag() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextDataBag() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextDataByteArray() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNextDataByteArray() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextDataByteArray() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextDataByteArray() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextDataByteArray() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNextDataByteArray() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNextDataByteArray() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextDataByteArray() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextDataByteArray() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextDateTime() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNextDateTime() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextDateTime() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextDateTime() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextDateTime() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNextDateTime() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNextDateTime() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextDateTime() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextDateTime() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
getNextDouble() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
getNextDouble() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
getNextFloat() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
getNextFloat() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextGlobalClassIdentifier() - Static method in class org.apache.pig.data.SchemaTupleClassGenerator
 
getNextHelper(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
getNextId(String) - Static method in class org.apache.pig.parser.LogicalPlanBuilder
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
getNextInteger() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Mod
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
getNextInteger() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextInvocationPoint() - Method in class org.apache.pig.parser.PigParserNode
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
getNextLong() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Mod
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
getNextLong() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextMap() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNextMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNextMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNextMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextNodeId(String) - Method in class org.apache.pig.impl.plan.NodeIdGenerator
Returns the next ID to be used for the current Thread.
getNextOpt() - Method in class org.apache.pig.tools.cmdline.CmdLineParser
Get the next option.
getNextPlan(List<TezOperPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainer
 
getNextString() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNextString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNextString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNextString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextTuple() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
Asked for Tuples.
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
Attaches the proccesed input tuple to the expression plan and checks if comparison operator returns a true.
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
Calls getNext on the generate operator inside the nested physical plan and returns it maintaining an additional state to denote the begin and end of the nested plan processing.
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
Counts the number of tuples processed into static variable soFar, if the number of tuples processed reach the limit, return EOP; Otherwise, return the tuple
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
The main method used by this operator's successor to read tuples from the specified file using the specified load function.
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
Calls getNext on the generate operator inside the nested physical plan.
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POOptimizedForEach
Calls getNext on the generate operator inside the nested physical plan and returns it maintaining an additional state to denote the begin and end of the nested plan processing.
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
From the inputs, constructs the output tuple for this co-group in the required format which is (key, {bag of tuples from input 1}, {bag of tuples from input 2}, ...)
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartitionRearrange
Calls getNext on the generate operator inside the nested physical plan.
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
Calls getNext on the generate operator inside the nested physical plan.
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POReservoirSample
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSortedDistinct
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
The code below, tries to follow our single threaded shared execution model with execution being passed around each non-drained input
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POPoissonSampleSpark
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBloomFilterRearrangeTez
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterTez
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POIdentityInOutTez
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POPartitionRearrangeTez
Calls getNext on the generate operator inside the nested physical plan.
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.PORankTez
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffledValueInputTez
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffleTezLoad
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POSimpleTezLoad
Previously, we reused the same Result object for all results, but we found certain operators (e.g.
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POStoreTez
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueInputTez
 
getNextTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
getNextUid() - Static method in class org.apache.pig.newplan.logical.expression.LogicalExpression
 
getNull() - Method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
getNumberBytes(String) - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getNumberBytes(String) - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the number of bytes for the given output location, -1 for invalid location or name.
getNumberFailedJobs() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getNumberFailedJobs() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getNumberJobs() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getNumberJobs() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the number of jobs for this script
getNumberJobs() - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
getNumberMaps() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getNumberMaps() instead.
getNumberMaps() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getNumberMaps() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getNumberMaps() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getNumberMaps() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getNumberRecords(String) - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getNumberRecords() - Method in class org.apache.pig.tools.pigstats.InputStats
 
getNumberRecords() - Method in class org.apache.pig.tools.pigstats.OutputStats
 
getNumberRecords(String) - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the number of records for the given output location, -1 for invalid location or name.
getNumberReduces() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getNumberReduces() instead.
getNumberReduces() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getNumberReduces() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getNumberReduces() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getNumberReduces() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getNumberSuccessfulJobs() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getNumberSuccessfulJobs() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getNumBloomFilters(Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
getNumDistinctChanged() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SecondaryKeyOptimizerMR
 
getNumDistinctChanged() - Method in interface org.apache.pig.backend.hadoop.executionengine.optimizer.SecondaryKeyOptimizer
 
getNumDistinctChanged() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.SecondaryKeyOptimizerSpark
 
getNumDistinctChanged() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.SecondaryKeyOptimizerTez
 
getNumDistinctChanged() - Method in class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil.SecondaryKeyOptimizerInfo
 
getNumDistinctValues() - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
getNumInps() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
getNumInputs(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
 
getNumInputs(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getNumInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getNumLogicalRelationOperators() - Method in class org.apache.pig.newplan.logical.relational.LogicalPlanData
Returns the number of LogicalRelationalOperators present in the pig script.
getNumMRUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SecondaryKeyOptimizer
 
getNumObjectsSizeAdded() - Method in class org.apache.pig.data.SelfSpillBag.MemoryLimits
 
getNumPaths() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getNumPaths() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
getNumPaths() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
getNumPaths() - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit
 
getNumRecords() - Method in class org.apache.pig.ResourceStatistics
 
getNumSamples() - Method in class org.apache.pig.impl.builtin.SampleLoader
 
getNumSinks() - Method in class org.apache.pig.newplan.logical.relational.LogicalPlanData
 
getNumSortRemoved() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SecondaryKeyOptimizer
 
getNumSortRemoved() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SecondaryKeyOptimizerMR
 
getNumSortRemoved() - Method in interface org.apache.pig.backend.hadoop.executionengine.optimizer.SecondaryKeyOptimizer
 
getNumSortRemoved() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.SecondaryKeyOptimizerSpark
 
getNumSortRemoved() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.SecondaryKeyOptimizerTez
 
getNumSortRemoved() - Method in class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil.SecondaryKeyOptimizerInfo
 
getNumSources() - Method in class org.apache.pig.newplan.logical.relational.LogicalPlanData
 
getNumUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SecondaryKeyOptimizerMR
 
getNumUseSecondaryKey() - Method in interface org.apache.pig.backend.hadoop.executionengine.optimizer.SecondaryKeyOptimizer
 
getNumUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.SecondaryKeyOptimizerSpark
 
getNumUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.SecondaryKeyOptimizerTez
 
getNumUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil.SecondaryKeyOptimizerInfo
 
getObjectRegistry() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.ObjectCache
Returns the tez ObjectRegistry which allows caching of objects at the Session, DAG and Vertex level on container reuse for better performance and savings
getOffset() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator.OriginalLocation
 
getOffset(Tuple) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Extracts the offset into the data file from the index tuple.
getOp() - Method in class org.apache.pig.builtin.BigDecimalMax.Final
 
getOp() - Method in class org.apache.pig.builtin.BigDecimalMax.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.BigDecimalMin.Final
 
getOp() - Method in class org.apache.pig.builtin.BigDecimalMin.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.BigDecimalSum.Final
 
getOp() - Method in class org.apache.pig.builtin.BigDecimalSum.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.BigIntegerMax.Final
 
getOp() - Method in class org.apache.pig.builtin.BigIntegerMax.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.BigIntegerMin.Final
 
getOp() - Method in class org.apache.pig.builtin.BigIntegerMin.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.BigIntegerSum.Final
 
getOp() - Method in class org.apache.pig.builtin.BigIntegerSum.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.DoubleMax.Final
 
getOp() - Method in class org.apache.pig.builtin.DoubleMax.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.DoubleMin.Final
 
getOp() - Method in class org.apache.pig.builtin.DoubleMin.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.DoubleSum.Final
 
getOp() - Method in class org.apache.pig.builtin.DoubleSum.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.FloatMax.Final
 
getOp() - Method in class org.apache.pig.builtin.FloatMax.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.FloatMin.Final
 
getOp() - Method in class org.apache.pig.builtin.FloatMin.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.IntMax.Final
 
getOp() - Method in class org.apache.pig.builtin.IntMax.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.IntMin.Final
 
getOp() - Method in class org.apache.pig.builtin.IntMin.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.LongMax.Final
 
getOp() - Method in class org.apache.pig.builtin.LongMax.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.LongMin.Final
 
getOp() - Method in class org.apache.pig.builtin.LongMin.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.LongSum.Final
 
getOp() - Method in class org.apache.pig.builtin.LongSum.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.MAX.Final
 
getOp() - Method in class org.apache.pig.builtin.MAX.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.MIN.Final
 
getOp() - Method in class org.apache.pig.builtin.MIN.Intermediate
 
getOp() - Method in class org.apache.pig.builtin.SUM.Final
 
getOp() - Method in class org.apache.pig.builtin.SUM.Intermediate
 
getOperandType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryComparisonOperator
 
getOperandType() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
Determine the type of the operand(s) of this comparator.
getOperandType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryComparisonOperator
 
getOperationID() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getOperationID() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
getOperationID() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
getOperations() - Method in class org.apache.pig.newplan.logical.relational.LOCube
 
getOperator(OperatorKey) - Method in class org.apache.pig.impl.plan.OperatorPlan
Given an OperatorKey, find the associated operator.
getOperatorKey() - Method in class org.apache.pig.impl.plan.Operator
Get the operator key for this operator.
getOperatorKey(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Given an operator, find its OperatorKey.
getOperators() - Method in class org.apache.pig.newplan.BaseOperatorPlan
 
getOperators() - Method in interface org.apache.pig.newplan.OperatorPlan
Get an iterator of all operators in this plan
getOperators() - Method in class org.apache.pig.newplan.OperatorSubPlan
 
getOperators() - Method in class org.apache.pig.parser.QueryParserDriver
 
getOpsToBeReset() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
getOpType() - Method in class org.apache.pig.Expression
 
getOriginalLimit() - Method in class org.apache.pig.pen.Illustrator
 
getOriginalLocations() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getOriginalReturnType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getOriLimitMap() - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
getOutput() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
getOutputAlias(String) - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getOutputAlias(String) - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the alias associated with this output location
getOutputAvroSchema() - Method in class org.apache.pig.builtin.AvroStorage
Utility function that gets the output schema from the udf properties for this instance of the store function.
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigOutputFormatTez
 
getOutputFormat() - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
getOutputFormat() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
getOutputFormat() - Method in class org.apache.pig.builtin.AvroStorage
 
getOutputFormat() - Method in class org.apache.pig.builtin.BinStorage
 
getOutputFormat() - Method in class org.apache.pig.builtin.JsonStorage
 
getOutputFormat() - Method in class org.apache.pig.builtin.mock.Storage
 
getOutputFormat() - Method in class org.apache.pig.builtin.OrcStorage
 
getOutputFormat() - Method in class org.apache.pig.builtin.PigStorage
 
getOutputFormat() - Method in class org.apache.pig.builtin.TrevniStorage
 
getOutputFormat() - Method in class org.apache.pig.impl.io.InterStorage
 
getOutputFormat() - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
getOutputFormat() - Method in class org.apache.pig.impl.io.TFileStorage
 
getOutputFormat() - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
getOutputFormat() - Method in class org.apache.pig.piggybank.storage.DBStorage
 
getOutputFormat() - Method in class org.apache.pig.piggybank.storage.FixedWidthStorer
 
getOutputFormat() - Method in class org.apache.pig.piggybank.storage.HiveColumnarStorage
 
getOutputFormat() - Method in class org.apache.pig.piggybank.storage.IndexedStorage
 
getOutputFormat() - Method in class org.apache.pig.piggybank.storage.MultiStorage
 
getOutputFormat() - Method in class org.apache.pig.StoreFunc
Return the OutputFormat associated with StoreFunc.
getOutputFormat() - Method in interface org.apache.pig.StoreFuncInterface
Return the OutputFormat associated with StoreFuncInterface.
getOutputFormat() - Method in class org.apache.pig.StoreFuncWrapper
 
getOutputFormatEntries(Configuration) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
getOutputKey() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POStoreTez
 
getOutputLocations() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getOutputLocations() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the list of output locations in the script
getOutputNames() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getOutputNames() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the list of output names in the script
getOutputPlans() - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
getOutputPlanSchemas() - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
Get the output schema corresponding to each input expression plan
getOutputs() - Method in class org.apache.pig.tools.pigstats.JobStats
 
getOutputSize(POStore, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.FileBasedOutputSizeReader
Returns the total size of output files in bytes
getOutputSize(POStore, Configuration) - Method in interface org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigStatsOutputSizeReader
Returns the size of output in bytes.
getOutputSize(POStore, Configuration) - Static method in class org.apache.pig.tools.pigstats.JobStats
Looks up the output size reader from OUTPUT_SIZE_READER_KEY and invokes it to get the size of output.
getOutputSpec() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get the specification of the primary output of the StreamingCommand.
getOutputSpec() - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
getOutputStats() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getOutputStats() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getOutputType() - Method in class org.apache.pig.impl.streaming.DefaultOutputHandler
 
getOutputType() - Method in class org.apache.pig.impl.streaming.FileOutputHandler
 
getOutputType() - Method in class org.apache.pig.impl.streaming.OutputHandler
Get the handled OutputType.
getOutputTypeClass() - Method in class org.apache.pig.TypedOutputEvalFunc
 
getPack(Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
 
getPack(Reducer.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
 
getPackageImportList() - Static method in class org.apache.pig.impl.PigContext
 
getPackagers() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
Returns the list of packages.
getPackageType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getParallelism(List<<any>>, PhysicalOperator) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigContext
 
getParallelism() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
getParallelismFactor(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getParamDelim() - Method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
getParamFiles() - Method in class org.apache.pig.impl.PigContext
 
getParams() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PONative
 
getParams() - Method in class org.apache.pig.impl.PigContext
 
getParams() - Method in class org.apache.pig.newplan.logical.relational.LONative
 
getParamsFromVariables() - Method in class org.apache.pig.scripting.groovy.GroovyScriptEngine
 
getParamsFromVariables() - Method in class org.apache.pig.scripting.jruby.JrubyScriptEngine
 
getParamsFromVariables() - Method in class org.apache.pig.scripting.js.JsScriptEngine
 
getParamsFromVariables() - Method in class org.apache.pig.scripting.jython.JythonScriptEngine
 
getParamsFromVariables() - Method in class org.apache.pig.scripting.ScriptEngine
Returns a map from local variable names to their values
getParamsFromVariables() - Method in class org.apache.pig.scripting.streaming.python.PythonScriptEngine
 
getParamVal() - Method in class org.apache.pig.impl.PigContext
 
getParamVal() - Method in class org.apache.pig.tools.parameters.PreprocessorContext
 
getParentPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getPartition(PigNullableWritable, Writable, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SecondaryKeyPartitioner
 
getPartition(PigNullableWritable, Writable, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SkewedPartitioner
 
getPartition(PigNullableWritable, Writable, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
getPartition(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.MapReducePartitionerWrapper
 
getPartition(Writable, Writable, int) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.HashValuePartitioner
 
getPartition(PigNullableWritable, Writable, int) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.WeightedRangePartitionerTez
 
getPartition(Writable, Writable, int) - Method in class org.apache.pig.builtin.RoundRobinPartitioner
Deprecated.
 
getPartition() - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
getPartitioner(String, int) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkUtil
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.builtin.AvroStorage
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.builtin.BinStorage
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.builtin.JsonLoader
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.builtin.JsonMetadata
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.builtin.mock.Storage
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.builtin.OrcStorage
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.builtin.PigStorage
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.impl.io.InterStorage
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.impl.io.ReadToEndLoader
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.impl.io.TFileStorage
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.LoadFuncMetadataWrapper
 
getPartitionKeys(String, Job) - Method in interface org.apache.pig.LoadMetadata
Find what columns are partition keys for this input.
getPartitionKeys(String, Job) - Method in class org.apache.pig.piggybank.storage.AllLoader
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.piggybank.storage.FixedWidthLoader
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.piggybank.storage.FixedWidthStorer
 
getPartitionKeys(String, Job) - Method in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
getPartitionKeys(String, Configuration) - Method in class org.apache.pig.piggybank.storage.partition.PathPartitioner
Searches for the key=value pairs in the path pointer by the location parameter.
getPartitionKeys(String, Configuration) - Method in class org.apache.pig.piggybank.storage.partition.PathPartitionHelper
Returns the partition keys for a location.
The work is delegated to the PathPartitioner class
getPatchVersion() - Static method in class org.apache.pig.Main
Returns the patch version of the Pig build being run.
getPath() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
getPath() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
getPathLength(FileSystem, FileStatus) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
 
getPathLength(FileSystem, FileStatus, long) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
Returns the total number of bytes for this file, or if a directory all files in the directory.
getPathPartitionKeyValues(String) - Method in class org.apache.pig.piggybank.storage.partition.PathPartitioner
Note: this must be the path lowes in the Searches for the key=value pairs in the path pointer by the location parameter.
getPathPartitionKeyValues(String) - Method in class org.apache.pig.piggybank.storage.partition.PathPartitionHelper
Returns the Partition keys and each key's value for a single location.
That is the location must be something like mytable/partition1=a/partition2=b/myfile.
This method will return a map with [partition1='a', partition2='b']
The work is delegated to the PathPartitioner class
getPaths(String, Configuration, boolean) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
Gets the list of paths from the pathString specified which may contain comma-separated paths and glob style path
getPathsToSkip() - Method in class org.apache.pig.impl.PigContext
Get paths which are to skipped while automatically shipping binaries for streaming.
getPathStrings(String) - Static method in class org.apache.pig.impl.util.StringUtils
 
getPathStrings(String) - Static method in class org.apache.pig.LoadFunc
Parse comma separated path strings into a string array.
getPattern() - Method in class org.apache.pig.newplan.optimizer.Rule
Return the pattern to be matched for this rule
getPattern() - Method in class org.apache.pig.piggybank.storage.apachelog.CombinedLogLoader
 
getPattern() - Method in class org.apache.pig.piggybank.storage.apachelog.CommonLogLoader
 
getPattern() - Method in class org.apache.pig.piggybank.storage.MyRegExLoader
 
getPattern() - Method in class org.apache.pig.piggybank.storage.RegExLoader
 
getPc() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
getPerfTimerFactory() - Static method in class org.apache.pig.tools.timer.PerformanceTimerFactory
Get the timer factory.
getPermissionException(Exception) - Static method in class org.apache.pig.impl.util.LogUtils
 
getPersistStderr() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Should the stderr of the managed process be persisted?
getPhysicalOperators(PhysicalPlan, Class<C>) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.PlanHelper
Returns a LinkedList of operators contained within the physical plan which implement the supplied class, in dependency order.
getPhysicalPlan() - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
getPhysicalPlan() - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
getPhyToMRMap() - Method in class org.apache.pig.pen.LocalMapReduceSimulator
 
getPigAuditId(PigContext) - Static method in class org.apache.pig.backend.hadoop.PigATSClient
 
getPigContext() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartitionRearrange
 
getPigContext() - Method in class org.apache.pig.PigServer
 
getPigContext() - Method in class org.apache.pig.scripting.ScriptPigContext
 
getPigContext() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getPigContext() - Method in class org.apache.pig.tools.pigstats.ScriptState
 
getPigException(Throwable) - Static method in class org.apache.pig.impl.util.LogUtils
 
getPigFeature(MapReduceOper) - Method in class org.apache.pig.tools.pigstats.mapreduce.MRScriptState
 
getPigFeatures(SparkOperator) - Method in class org.apache.pig.tools.pigstats.spark.SparkScriptState.SparkScriptInfo
 
getPigFeatures() - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState.TezDAGScriptInfo
 
getPigFeatures(TezOperator) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState.TezDAGScriptInfo
 
getPigLogger() - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getPigLogger() - Method in class org.apache.pig.EvalFunc
 
getPigNullableWritable(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
getPigObject(Object) - Static method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
getPigObjMemSize(Object) - Static method in class org.apache.pig.data.SizeUtil
 
getPigProperties() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the properties associated with the script
getPigSchema(ResourceSchema) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
getPigSchema(byte, String) - Static method in class org.apache.pig.piggybank.storage.avro.AvroSchema2Pig
Wrap a pig type to a field schema
getPigSplits(List<InputSplit>, int, ArrayList<OperatorKey>, long, boolean, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
getPigStats(int) - Static method in class org.apache.pig.tools.pigstats.PigStatsUtil
Returns the PigStats with the given return code
getPigStatsMap() - Method in class org.apache.pig.scripting.ScriptEngine
Gets the collection of PigStats after the script is run.
getPigType(Schema) - Static method in class org.apache.pig.impl.util.avro.AvroStorageSchemaConversionUtilities
Determines the pig object type of the Avro schema.
getPigVersion() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getPigVersion() - Method in class org.apache.pig.tools.pigstats.ScriptState
 
getPkgOp() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POJoinGroupSpark
 
getPKGOp() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
getPkgr() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
getPlainForEachOP(String, NodeIdGenerator) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRUtil
 
getPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
Used to get the plan that was compiled
getPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter.InnerOperator
 
getPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
 
getPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter.InnerOperator
 
getPlan() - Method in class org.apache.pig.impl.plan.PlanVisitor
 
getPlan() - Method in class org.apache.pig.impl.plan.PlanWalker
 
getPlan() - Method in class org.apache.pig.newplan.Operator
Get the plan associated with this operator.
getPlan() - Method in class org.apache.pig.newplan.PlanVisitor
 
getPlan() - Method in class org.apache.pig.newplan.PlanWalker
 
getPlan(String) - Method in class org.apache.pig.PigServer.Graph
 
getPlanContainer() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
getPlanLeafOps() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
getPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
getPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Returns the list of inner plans.
getPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
getPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
getPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
Returns the list of nested plans.
getPlans() - Method in class org.apache.pig.tools.ToolsPigServer
Get a class containing the Pig plans.
getPos() - Method in class org.apache.pig.piggybank.storage.avro.PigAvroRecordReader
 
getPosition() - Method in class org.apache.pig.impl.io.BufferedPositionedInputStream
Returns the current position in the tracked InputStream.
getPosition(String) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Given an alias, find the associated position of the field schema.
getPositionSubName(String) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Given an alias, find the associated position of the field schema.
getPOStore() - Method in interface org.apache.pig.backend.executionengine.ExecJob
 
getPOStore() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getPOStore() - Method in class org.apache.pig.tools.pigstats.OutputStats
 
getPreCombinerLR(POLocalRearrange) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil
 
getPredecessors() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POJoinGroupSpark
 
getPredecessors(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Find all of the nodes that have edges to the indicated node from themselves.
getPredecessors(Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
For a given operator, get all operators immediately before it in the plan.
getPredecessors(Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
For a given operator, get all operators immediately before it in the plan.
getPredecessors(Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
getPredicateFields(String, Job) - Method in class org.apache.pig.builtin.OrcStorage
 
getPredicateFields(String, Job) - Method in interface org.apache.pig.LoadPredicatePushdown
Find what fields of the data can support predicate pushdown.
getPreprocessorContext() - Method in class org.apache.pig.impl.PigContext
 
getPrimaryFromHive(Object, PrimitiveObjectInspector) - Static method in class org.apache.pig.impl.util.hive.HiveUtils
 
getProactiveSpillCountObjects() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getProactiveSpillCountObjects() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getProactiveSpillCountObjects() instead.
getProactiveSpillCountObjects() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getProactiveSpillCountObjects() - Method in class org.apache.pig.tools.pigstats.mapreduce.SimplePigStats
 
getProactiveSpillCountObjects() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the total number of bags that spilled proactively
getProactiveSpillCountObjects() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getProactiveSpillCountObjects() - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
getProactiveSpillCountObjects() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
getProactiveSpillCountObjects() - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
getProactiveSpillCountObjects() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
getProactiveSpillCountRecords() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getProactiveSpillCountRecords() - Method in class org.apache.pig.tools.pigstats.mapreduce.SimplePigStats
 
getProactiveSpillCountRecords() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the total number of records that spilled proactively
getProactiveSpillCountRecords() - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
getProactiveSpillCountRecords() - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
getProactiveSpillCountRecs() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getProactiveSpillCountRecs() instead.
getProactiveSpillCountRecs() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getProactiveSpillCountRecs() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getProactiveSpillCountRecs() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
getProactiveSpillCountRecs() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
getProbVec(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
getProcessorName() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getProduct2Manifest() - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkUtil
 
getProgress() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.IllustrateDummyReporter
 
getProgress() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigRecordReader
 
getProgress() - Method in class org.apache.pig.backend.hadoop.executionengine.TaskContext
 
getProgress() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableRecordReader
 
getProgress() - Method in class org.apache.pig.impl.io.BinStorageRecordReader
Get the progress within the split
getProgress() - Method in class org.apache.pig.impl.io.InterRecordReader
Get the progress within the split
getProgress() - Method in class org.apache.pig.impl.io.TFileRecordReader
Get the progress within the split
getProgress() - Method in class org.apache.pig.impl.util.avro.AvroArrayReader
 
getProgress() - Method in class org.apache.pig.impl.util.avro.AvroRecordReader
 
getProgress() - Method in class org.apache.pig.pen.FakeRawKeyValueIterator
 
getProgress() - Method in class org.apache.pig.piggybank.storage.AllLoader.AllReader
 
getProgress() - Method in class org.apache.pig.piggybank.storage.avro.PigAvroRecordReader
 
getProgress() - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCRecordReader
 
getProgress() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader
 
getProgress() - Method in class org.apache.pig.piggybank.storage.XMLLoader.XMLRecordReader
 
getProgress() - Method in class org.apache.pig.tools.pigstats.PigStatusReporter
 
getProjectedColsMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
getProjectedOperator() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
getProjection() - Method in class org.apache.pig.newplan.logical.relational.LOInnerLoad
 
getProjectionMap() - Method in class org.apache.pig.impl.plan.Operator
Produce a map describing how this operator modifies its projection.
getProperties() - Method in class org.apache.pig.builtin.AvroStorage
Internal function for getting the Properties object associated with this UDF instance.
getProperties(Class, String) - Method in class org.apache.pig.builtin.AvroStorage
Internal function for getting the Properties object associated with this UDF instance.
getProperties() - Method in class org.apache.pig.impl.PigContext
Provides configuration information.
getPushDownExpression() - Method in class org.apache.pig.newplan.FilterExtractor
 
getQuantFile() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getQuickGenerator() - Method in class org.apache.pig.data.SchemaTuple
This is a mechanism which allows the SchemaTupleFactory to get around having to use reflection.
getRankColPlans() - Method in class org.apache.pig.newplan.logical.relational.LORank
 
getRankCounterOffset(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
getRankCounterOffset(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.PORankTez
 
getRankOperationId() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getRankPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
getRawColumns() - Method in class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
getRealness(Operator, Map<Operator, DataBag>, boolean) - Static method in class org.apache.pig.pen.util.MetricEvaluation
 
getRearrangedTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
getReceiver() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
getRecordCount(String) - Method in class org.apache.pig.CounterBasedErrorHandler
 
getRecordCount(POStore) - Static method in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
getRecordCount(POLoad) - Static method in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
getRecordDelim() - Method in class org.apache.pig.impl.streaming.PigStreamingUDF
 
getRecordDelimiter() - Method in class org.apache.pig.impl.streaming.OutputHandler
 
getRecordDelimiter() - Method in class org.apache.pig.impl.streaming.StreamingUDFOutputHandler
 
getRecordEnd() - Method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
getRecords() - Method in class org.apache.pig.tools.pigstats.OutputStats
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTextOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigOutputFormatTez
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.pig.impl.io.BinStorageOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.pig.impl.io.InterStorage.InterOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage.SequenceFileTupleOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.pig.impl.io.TFileStorage.TFileOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.MultiStorage.MultiStorageOutputFormat
 
getRecordWritten() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getRecordWritten() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the total number of records in user specified output locations of this script.
getRecordWrittern() - Method in class org.apache.pig.tools.pigstats.JobStats
Returns the total number of records in user specified output locations of this job.
getReduceInputRecords() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getReduceInputRecords() instead.
getReduceInputRecords() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getReduceInputRecords() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getReduceInputRecords() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getReduceInputRecords() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getReduceOutputRecords() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getReduceOutputRecords() instead.
getReduceOutputRecords() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getReduceOutputRecords() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getReduceOutputRecords() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
Deprecated.
getReduceOutputRecords() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
Deprecated.
getReferencedOperator() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getReferredExpression() - Method in class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
getRemainingArgs() - Method in class org.apache.pig.tools.cmdline.CmdLineParser
Get any remaining arguments.
getRemovedFields() - Method in class org.apache.pig.impl.plan.ProjectionMap
 
getReplFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
getReporter() - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getReporter() - Method in class org.apache.pig.EvalFunc
 
getRepresentative(Tuple) - Method in class org.apache.pig.impl.util.LineageTracer
 
getRepresentative(Tuple) - Method in class org.apache.pig.pen.util.LineageTracer
 
getRequestedParallelism() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getRequestedParallelism() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getRequestedParallelism() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
getRequestedParallelism() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getRequestedParallelism() - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
Get the requestedParallelism for this operator.
getRequiredFieldResponse() - Method in class org.apache.pig.LoadPushDown.RequiredFieldResponse
Indicates whether the loader will return only the requested fields or all fields.
getResourceFieldSchema(TypeInfo) - Static method in class org.apache.pig.impl.util.hive.HiveUtils
 
getResourcesDir() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezResourceManager
 
getResult() - Method in class org.apache.pig.parser.DryRunGruntParser
 
getResults() - Method in interface org.apache.pig.backend.executionengine.ExecJob
if query has executed successfully we want to retrieve the results via iterating over them.
getResults() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getResultType() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnInfo
 
getResultType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getReturnCode() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns code are defined in PigRunner.ReturnCode
getReturnType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getReturnType() - Method in class org.apache.pig.builtin.Invoker
 
getReturnType() - Method in class org.apache.pig.EvalFunc
Get the Type that this EvalFunc returns.
getReturnType() - Method in class org.apache.pig.impl.builtin.GetMemNumRows
 
getReturnType() - Method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
 
getRhs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
getRhs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
Get right expression
getRhs() - Method in class org.apache.pig.Expression.BinaryExpression
 
getRhs() - Method in class org.apache.pig.newplan.logical.expression.BinaryExpression
Get the right hand side of this binary expression.
getRhs() - Method in class org.apache.pig.newplan.logical.expression.BinCondExpression
Get the right hand side of this expression.
getRoots() - Method in class org.apache.pig.impl.plan.OperatorPlan
Get a list of all nodes in the graph that are roots.
getRunId() - Static method in class org.apache.pig.scripting.ScriptingOutputCapturer
 
getS3Conf() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
getSampleOperator() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getScalars() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.ScalarPhyFinder
 
getSchema(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
getSchema() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getSchema(String, Job) - Method in class org.apache.pig.builtin.AvroStorage
 
getSchema(String, Job) - Method in class org.apache.pig.builtin.BinStorage
 
getSchema(String, Job) - Method in class org.apache.pig.builtin.JsonLoader
 
getSchema(String, Job) - Method in class org.apache.pig.builtin.JsonMetadata
For JsonMetadata schema is considered optional This method suppresses (and logs) errors if they are encountered.
getSchema(String, Job, boolean) - Method in class org.apache.pig.builtin.JsonMetadata
Read the schema from json metadata file If isSchemaOn parameter is false, the errors are suppressed and logged
getSchema(String) - Method in class org.apache.pig.builtin.mock.Storage.Data
 
getSchema(String, Job) - Method in class org.apache.pig.builtin.mock.Storage
 
getSchema(String, Job) - Method in class org.apache.pig.builtin.OrcStorage
 
getSchema(String, Job) - Method in class org.apache.pig.builtin.PigStorage
 
getSchema() - Method in interface org.apache.pig.data.TypeAwareTuple
 
getSchema(String, Job) - Method in class org.apache.pig.impl.io.InterStorage
 
getSchema(String, Job) - Method in class org.apache.pig.impl.io.ReadToEndLoader
 
getSchema(String, Job) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
getSchema(String, Job) - Method in class org.apache.pig.impl.io.TFileStorage
 
getSchema(LoadFunc, String, boolean, Job) - Static method in class org.apache.pig.impl.util.Utils
 
getSchema(String, Job) - Method in class org.apache.pig.LoadFuncMetadataWrapper
 
getSchema(String, Job) - Method in interface org.apache.pig.LoadMetadata
Get a schema for the data to be loaded.
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOCross
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOCube
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LODistinct
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOFilter
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOForEach
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
Get the schema for the output of this relational operator.
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOInnerLoad
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOLimit
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
Get the schema for this load.
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LONative
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LORank
Get the schema for the output of LORank.
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOSplit
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOSplitOutput
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOStream
 
getSchema() - Method in class org.apache.pig.newplan.logical.relational.LOUnion
 
getSchema() - Method in class org.apache.pig.pen.Illustrator
 
getSchema(String, Job) - Method in class org.apache.pig.piggybank.storage.AllLoader
 
getSchema(String) - Method in class org.apache.pig.piggybank.storage.avro.AvroSchemaManager
Look up schema using type name or field name
getSchema(Path, FileSystem) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
getSchema(String, Job) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
Get avro schema from "location" and return the converted PigSchema.
getSchema(Path, FileSystem) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
This method is called by #getAvroSchema.
getSchema(String, Job) - Method in class org.apache.pig.piggybank.storage.FixedWidthLoader
 
getSchema(String, Job) - Method in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
getSchema() - Method in class org.apache.pig.ResourceSchema.ResourceFieldSchema
Get the schema for this field.
getSchemaFile() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
getSchemaFromBagSchemaString(String) - Static method in class org.apache.pig.impl.util.Utils
getSchemaFromBagSchemaString NOTE: use this call when you need to generate a Schema object from the representation generated by Schema#toString.
getSchemaFromFile(Path, FileSystem) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
This method is called to return the schema of an avro schema file.
getSchemaFromString(String) - Static method in class org.apache.pig.impl.util.Utils
 
getSchemaName(String, Schema) - Method in class org.apache.pig.EvalFunc
 
getSchemaString() - Method in class org.apache.pig.data.SchemaTuple
 
getSchemaToMergedSchemaMap(Schema, Map<Path, Schema>) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
When merging multiple avro record schemas, we build a map (schemaToMergedSchemaMap) to associate each input record with a remapping of its fields relative to the merged schema.
getSchemaTupleIdentifier() - Method in class org.apache.pig.data.SchemaTuple
This method will return the identifier that the generated code was generated with.
getSchemaType() - Method in class org.apache.pig.builtin.CONCAT
 
getSchemaType() - Method in class org.apache.pig.builtin.SPRINTF
 
getSchemaType() - Method in class org.apache.pig.builtin.StringConcat
 
getSchemaType() - Method in class org.apache.pig.EvalFunc
Returns the EvalFunc.SchemaType of the EvalFunc.
getSchemaWithInputSourceTag(ResourceSchema, String) - Static method in class org.apache.pig.impl.util.Utils
This method adds FieldSchema of 'input source tag/path' as the first field.
getScope() - Method in class org.apache.pig.impl.plan.OperatorKey
 
getScript() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the contents of the script that was run.
getScript() - Method in class org.apache.pig.tools.pigstats.ScriptState
 
getScriptAsStream(String) - Static method in class org.apache.pig.scripting.ScriptEngine
open a stream load a script locally or in the classpath
getScriptCache() - Method in class org.apache.pig.PigServer.Graph
 
getScriptEngine() - Method in class org.apache.pig.scripting.ScriptPigContext
 
getScriptFeatures() - Method in class org.apache.pig.tools.pigstats.ScriptState
 
getScriptFiles() - Method in class org.apache.pig.impl.PigContext
script files as name/file pairs to be added to the job jar
getScriptId() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getScriptInfo() - Method in class org.apache.pig.tools.pigstats.spark.SparkScriptState
 
getScriptingLang() - Method in class org.apache.pig.scripting.groovy.GroovyScriptEngine
 
getScriptingLang() - Method in class org.apache.pig.scripting.jruby.JrubyScriptEngine
 
getScriptingLang() - Method in class org.apache.pig.scripting.js.JsScriptEngine
 
getScriptingLang() - Method in class org.apache.pig.scripting.jython.JythonScriptEngine
 
getScriptingLang() - Method in class org.apache.pig.scripting.ScriptEngine
Gets ScriptEngine classname or keyword for the scripting language
getScriptingLang() - Method in class org.apache.pig.scripting.streaming.python.PythonScriptEngine
 
getScriptSchema(String, Configuration) - Static method in class org.apache.pig.impl.util.Utils
A helper function for retrieving the script schema set by the LOLoad function.
getScriptSchema() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
getScriptSchema() - Method in class org.apache.pig.newplan.logical.relational.LOStream
 
getScriptSchemaKey(String) - Static method in class org.apache.pig.impl.util.Utils
 
GetSecond - Class in org.apache.pig.builtin
GetSecond extracts the second of a minute from a DateTime object.
GetSecond() - Constructor for class org.apache.pig.builtin.GetSecond
 
getSecond() - Method in class org.apache.pig.data.utils.StructuresHelper.Pair
 
getSecond() - Method in class org.apache.pig.data.utils.StructuresHelper.Triple
 
getSecondaryProjectedColsMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
getSecondarySortOrder() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getSecondarySortOrder() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POGlobalRearrangeSpark
 
getSecondarySortOrder() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
getSecondarySortOrder() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
getSecondarySortOrder() - Method in class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil.SecondaryKeyOptimizerInfo
 
getSeed(AlgebraicMathBase.KNOWN_OP) - Static method in class org.apache.pig.builtin.AlgebraicBigDecimalMathBase
 
getSeed(AlgebraicMathBase.KNOWN_OP) - Static method in class org.apache.pig.builtin.AlgebraicBigIntegerMathBase
 
getSeed(AlgebraicMathBase.KNOWN_OP) - Static method in class org.apache.pig.builtin.AlgebraicByteArrayMathBase
 
getSeed(AlgebraicMathBase.KNOWN_OP) - Static method in class org.apache.pig.builtin.AlgebraicDoubleMathBase
 
getSeed(AlgebraicMathBase.KNOWN_OP) - Static method in class org.apache.pig.builtin.AlgebraicFloatMathBase
 
getSeed(AlgebraicMathBase.KNOWN_OP) - Static method in class org.apache.pig.builtin.AlgebraicIntMathBase
 
getSeed(AlgebraicMathBase.KNOWN_OP) - Static method in class org.apache.pig.builtin.AlgebraicLongMathBase
 
getSequenceWriter(TaskAttemptContext) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage.SequenceFileTupleOutputFormat
 
getSerializedScript() - Method in class org.apache.pig.tools.pigstats.ScriptState
 
getSFile() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getSFile() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
getShipCacheProperties() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
getShipFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getShipFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.UdfCacheShipFilesVisitor
 
getShipFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
getShipFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getShipFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPOUserFuncVisitor
 
getShipFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOStreamVisitor
 
getShipFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOUserFuncVisitor
 
getShipFiles() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
getShipFiles() - Method in class org.apache.pig.builtin.AvroStorage
 
getShipFiles(Class[]) - Static method in class org.apache.pig.builtin.FuncUtils
Utility function to get a list of containing jars via classes
getShipFiles(List<Class>) - Static method in class org.apache.pig.builtin.FuncUtils
 
getShipFiles() - Method in class org.apache.pig.builtin.HiveUDF
 
getShipFiles() - Method in class org.apache.pig.builtin.JsonLoader
 
getShipFiles() - Method in class org.apache.pig.builtin.JsonStorage
 
getShipFiles() - Method in class org.apache.pig.builtin.OrcStorage
 
getShipFiles() - Method in class org.apache.pig.EvalFunc
Allow a UDF to specify a list of local files it would like placed in the distributed cache.
getShipFiles() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get whether files for this command should be shipped or not.
getShipFiles() - Method in class org.apache.pig.LoadFunc
Allow a LoadFunc to specify a list of files located locally and would like to ship to backend (through distributed cache).
getShipFiles() - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
getShipFiles() - Method in interface org.apache.pig.StoreResources
Allow a StoreFunc to specify a list of files located locally and would like to ship to backend (through distributed cache).
getShipSpecs() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get the list of files which need to be shipped to the cluster.
getShortName(String) - Static method in class org.apache.pig.tools.pigstats.PigStatsUtil
 
getSignature() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getSignature() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
getSignature() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
getSignature() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getSignature() - Method in class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
getSignature() - Method in class org.apache.pig.newplan.logical.relational.LogicalPlan
Returns the signature of the LogicalPlan.
getSignature() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
getSignature() - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
getSinks() - Method in class org.apache.pig.newplan.BaseOperatorPlan
Get all operators in the plan that have no successors.
getSinks() - Method in class org.apache.pig.newplan.logical.relational.LogicalPlanData
 
getSinks() - Method in interface org.apache.pig.newplan.OperatorPlan
Get all operators in the plan that have no successors.
getSinks() - Method in class org.apache.pig.newplan.OperatorSubPlan
 
getSize(String) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
getSize(String, Properties) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
getSize() - Method in class org.apache.pig.impl.io.FileSpec
 
getSizeInBytes() - Method in class org.apache.pig.ResourceStatistics
 
getSkewedJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getSkewedJoinPartitionFile() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getSkewedJoinPartitionFile() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
getSMMSpillCount() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
getSMMSpillCount() - Method in class org.apache.pig.tools.pigstats.JobStats
Deprecated.
If you are using mapreduce, please cast JobStats to org.apache.pig.tools.pigstats.mapreduce.MRJobStats, then use MRJobStats.getSMMSpillCount() instead.
getSMMSpillCount() - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getSMMSpillCount() - Method in class org.apache.pig.tools.pigstats.mapreduce.SimplePigStats
 
getSMMSpillCount() - Method in class org.apache.pig.tools.pigstats.PigStats
Returns the total spill counts from SpillableMemoryManager.
getSMMSpillCount() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getSMMSpillCount() - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
getSMMSpillCount() - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
getSMMSpillCount() - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
getSMMSpillCount() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
getSoftLinkPredecessors(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Find all of the nodes that have soft edges to the indicated node from themselves.
getSoftLinkPredecessors(Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
For a given operator, get all operators softly immediately before it in the plan.
getSoftLinkPredecessors(Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
For a given operator, get all operators softly immediately before it in the plan.
getSoftLinkPredecessors(Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
getSoftLinkSuccessors(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Find all of the nodes that have soft edges from the indicated node to themselves.
getSoftLinkSuccessors(Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
For a given operator, get all operators softly immediately after it.
getSoftLinkSuccessors(Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
For a given operator, get all operators softly immediately after it.
getSoftLinkSuccessors(Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
getSortColInfoList() - Method in class org.apache.pig.SortInfo
 
getSortColPlans() - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
getSortCols(List<PhysicalPlan>) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
getSortInfo() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getSortInfo() - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
getSortInfo() - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
getSortKeyOrders() - Method in class org.apache.pig.ResourceSchema
Get order for sort keys.
getSortKeys() - Method in class org.apache.pig.ResourceSchema
Get the sort keys for this data.
getSortOperator() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getSortOrder() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getSortOrder() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getSortOrder() - Method in class org.apache.pig.SortColInfo
 
getSortPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
getSourceLocation() - Method in exception org.apache.pig.PigException
Return the location in the source that generated the exception.
getSources() - Method in class org.apache.pig.newplan.BaseOperatorPlan
Get all operators in the plan that have no predecessors.
getSources() - Method in class org.apache.pig.newplan.logical.relational.LogicalPlanData
 
getSources() - Method in interface org.apache.pig.newplan.OperatorPlan
Get all operators in the plan that have no predecessors.
getSources() - Method in class org.apache.pig.newplan.OperatorSubPlan
 
getSparkCounterGroups() - Method in class org.apache.pig.tools.pigstats.spark.SparkCounters
 
getSparkCounters() - Method in class org.apache.pig.tools.pigstats.spark.SparkCounterGroup
 
getSparkPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
getSpec() - Method in class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
Get the serializer/deserializer spec of the HandleSpec.
getSpillFile() - Method in class org.apache.pig.data.DefaultAbstractBag
Get a file to spill contents to.
getSplitComparable(InputSplit) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
getSplitComparable(InputSplit) - Method in class org.apache.pig.FileInputLoadFunc
 
getSplitComparable(InputSplit) - Method in interface org.apache.pig.OrderedLoadFunc
The WritableComparable object returned will be used to compare the position of different splits in an ordered stream
getSplitIndex() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getSplitIndex() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
getSplitIndex() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
getSplitIndex() - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit
 
getSplitParent() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getSplitPath() - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCRecordReader
 
getSplits(JobContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
getSplits(JobContext) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.running.PigInputFormatSpark
This is where we have to wrap PigSplits into SparkPigSplits
getSplits(JobContext) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat
 
getSplitStore() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
Returns the name of the file associated with this operator
getStackStraceStr(Throwable) - Static method in class org.apache.pig.impl.util.Utils
 
getStackTraceElement(String) - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
getStage() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
getStandardOutputRootWriteLocation() - Method in class org.apache.pig.scripting.ScriptingOutputCapturer
 
getStartCol() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnInfo
 
getStartCol() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getStartCol() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
getStartLine() - Method in class org.apache.pig.parser.PigParserNode
 
getState() - Method in class org.apache.pig.tools.pigstats.JobStats
 
getStatistics() - Method in interface org.apache.pig.backend.datastorage.DataStorage
Provides statistics on the Storage: capacity values, how much storage is in use...
getStatistics() - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
List entity statistics
getStatistics() - Method in interface org.apache.pig.backend.executionengine.ExecJob
Can be information about the state (not submitted, e.g.
getStatistics() - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
getStatistics() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
getStatistics() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getStatistics(String, Job) - Method in class org.apache.pig.builtin.AvroStorage
 
getStatistics(String, Job) - Method in class org.apache.pig.builtin.BinStorage
 
getStatistics(String, Job) - Method in class org.apache.pig.builtin.JsonLoader
 
getStatistics(String, Job) - Method in class org.apache.pig.builtin.JsonMetadata
For JsonMetadata stats are considered optional This method suppresses (and logs) errors if they are encountered.
getStatistics(String, Job) - Method in class org.apache.pig.builtin.mock.Storage
 
getStatistics(String, Job) - Method in class org.apache.pig.builtin.OrcStorage
 
getStatistics(String, Job) - Method in class org.apache.pig.builtin.PigStorage
 
getStatistics(String, Job) - Method in class org.apache.pig.impl.io.InterStorage
 
getStatistics(String, Job) - Method in class org.apache.pig.impl.io.ReadToEndLoader
 
getStatistics(String, Job) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
getStatistics(String, Job) - Method in class org.apache.pig.impl.io.TFileStorage
 
getStatistics(String, Job) - Method in class org.apache.pig.LoadFuncMetadataWrapper
 
getStatistics(String, Job) - Method in interface org.apache.pig.LoadMetadata
Get statistics about the data to be loaded.
getStatistics(String, Job) - Method in class org.apache.pig.piggybank.storage.AllLoader
 
getStatistics(String, Job) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
getStatistics(String, Job) - Method in class org.apache.pig.piggybank.storage.FixedWidthLoader
 
getStatistics(String, Job) - Method in class org.apache.pig.piggybank.storage.FixedWidthStorer
 
getStatistics(String, Job) - Method in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
getStats() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
getStatus() - Method in interface org.apache.pig.backend.executionengine.ExecJob
 
getStatus() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getSTDError(OutputStream) - Method in interface org.apache.pig.backend.executionengine.ExecJob
 
getSTDError(OutputStream) - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getSTDOut(OutputStream) - Method in interface org.apache.pig.backend.executionengine.ExecJob
 
getSTDOut(OutputStream) - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getStore() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
getStore(String, NodeIdGenerator) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
getStoreFunc() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getStoreFunc() - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
getStoreFuncDecorator() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getStoreFuncs() - Method in class org.apache.pig.newplan.logical.relational.LogicalPlanData
 
getStoreOutputDescriptor() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
getStorer() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.StoreFuncDecorator
 
getStores(Job) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
Returns all store locations of a previously compiled job
getStreamingCommand() - Method in class org.apache.pig.newplan.logical.relational.LOStream
Get the StreamingCommand object associated with this operator
getString(int) - Method in class org.apache.pig.data.SchemaTuple
 
getString(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
getStringFromArray(String[]) - Static method in class org.apache.pig.impl.util.Utils
 
getSubExpResults() - Method in class org.apache.pig.pen.Illustrator
 
getSubFields() - Method in class org.apache.pig.LoadPushDown.RequiredField
 
getSuccessfulJobs() - Method in class org.apache.pig.tools.pigstats.PigStats.JobGraph
 
getSuccessors(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Find all of the nodes that have edges from the indicated node to themselves.
getSuccessors(Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
For a given operator, get all operators immediately after it.
getSuccessors(Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
For a given operator, get all operators immediately after it.
getSuccessors(Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
getSupportedExpressionTypes() - Method in class org.apache.pig.builtin.OrcStorage
 
getSupportedExpressionTypes() - Method in interface org.apache.pig.LoadPredicatePushdown
Indicate operations on fields supported by the loader for predicate pushdown
getSupportedScriptLang(String) - Static method in class org.apache.pig.scripting.ScriptEngine
 
getSvnRevision() - Static method in class org.apache.pig.Main
Returns the svn revision number of the Pig build being run.
getTargetOps() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getTargetOps() - Method in class org.apache.pig.data.TargetedTuple
 
getTaskId() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
getTaskLogDir(String, String, String) - Method in class org.apache.pig.scripting.ScriptingOutputCapturer
 
getTaskReports(Job, TaskType) - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
getTempFileSpec(PigContext) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
Returns a temporary DFS Path
getTemporaryPath(PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
getTemporaryPath(PigContext, String) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
getTemporaryResourcePath(PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
Accessor method to get the resource ContainerDescriptor used for tez resource path bound to this thread.
getTezInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBloomFilterRearrangeTez
 
getTezInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
getTezInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POFRJoinTez
 
getTezInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POIdentityInOutTez
 
getTezInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.PORankTez
 
getTezInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffledValueInputTez
 
getTezInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffleTezLoad
 
getTezInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POSimpleTezLoad
 
getTezInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueInputTez
 
getTezInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.ReadScalarsTez
 
getTezInputs() - Method in interface org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezInput
 
getTezOperPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerNode
 
getTezOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
getTezOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
getTezOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterTez
 
getTezOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
getTezOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POStoreTez
 
getTezOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
getTezOutputs() - Method in interface org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezOutput
 
getTezPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
getTezResources(Set<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezResourceManager
 
getTezVersion() - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.TezExecType
 
getThird() - Method in class org.apache.pig.data.utils.StructuresHelper.Triple
 
getTimer(String) - Method in class org.apache.pig.tools.timer.PerformanceTimerFactory
Get a performance timer.
getTimeStamp() - Method in class org.apache.pig.data.TimestampedTuple
 
getTimeToSleep() - Method in class org.apache.pig.backend.hadoop.PigJobControl
 
getTmpFileCompressorName(PigContext) - Static method in class org.apache.pig.impl.util.Utils
 
getTmpFileStorageClass(Properties) - Static method in class org.apache.pig.impl.util.Utils
 
getTmpFileStorageObject(Configuration) - Static method in class org.apache.pig.impl.util.Utils
 
getToBeFlattened() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
getTotalCount() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.CountingMap
 
getTotalHadoopTimeSpent() - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
getTotalInputFileSize(Configuration, List<POLoad>, Job) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.InputSizeReducerEstimator
 
getTotalInputFilesSize() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getTuple(Key, Value) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
getTuple(Key, Value) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorage
 
getTuple(int) - Method in class org.apache.pig.data.SchemaTuple
 
getTuple(int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
getTuple2Manifest() - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkUtil
 
getTupleBegin() - Method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
getTuplebuffer() - Method in class org.apache.pig.data.AccumulativeBag
 
getTupleEnd() - Method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
getTupleRawComparatorClass() - Method in class org.apache.pig.data.BinInterSedes
 
getTupleRawComparatorClass() - Method in interface org.apache.pig.data.InterSedes
 
getTuples(int) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.AccumulativeTupleBuffer
Get iterator of tuples in the buffer
getTuples(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage.POPackageTupleBuffer
 
getTupleSize(DataInput, byte) - Method in class org.apache.pig.data.BinInterSedes
 
getType() - Method in class org.apache.pig.backend.hadoop.accumulo.Column
 
getType(int) - Method in class org.apache.pig.data.AbstractTuple
Find the type of a given field.
getType(int) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
getType(int) - Method in class org.apache.pig.data.SchemaTuple
 
getType(int) - Method in class org.apache.pig.data.TargetedTuple
 
getType(int) - Method in interface org.apache.pig.data.Tuple
Find the type of a given field.
getType(int) - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
getType() - Method in class org.apache.pig.LoadPushDown.RequiredField
 
getType() - Method in class org.apache.pig.newplan.logical.expression.LogicalExpression
Get the data type for this expression.
getType() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
getType(int) - Method in class org.apache.pig.pen.util.ExampleTuple
 
getType() - Method in class org.apache.pig.ResourceSchema.ResourceFieldSchema
Get the type of this field.
getTypeArguments(Class<T>, Class<? extends T>) - Static method in class org.apache.pig.TypedOutputEvalFunc
Get the actual type arguments a child class has used to extend a generic base class.
getTypeAwareBase(int, String) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
getTypeAwareBase(int, String) - Method in class org.apache.pig.data.SchemaTuple
 
getTypeInfo(ResourceSchema.ResourceFieldSchema) - Static method in class org.apache.pig.impl.util.hive.HiveUtils
 
getUdfConfs() - Method in class org.apache.pig.impl.util.UDFContext
 
getUDFContext() - Static method in class org.apache.pig.impl.util.UDFContext
 
getUDField(Schema, int) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
get field schema given index number
getUdfJars() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.UDFJarsFinder
 
getUDFList() - Method in class org.apache.pig.newplan.logical.visitor.UDFFinder
 
getUdfOutput() - Static method in class org.apache.pig.scripting.ScriptingOutputCapturer
 
getUDFProperties() - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
Returns UDFProperties based on contextSignature.
getUDFProperties(Class, String[]) - Method in class org.apache.pig.impl.util.UDFContext
Get a properties object that is specific to this UDF.
getUDFProperties(Class) - Method in class org.apache.pig.impl.util.UDFContext
Get a properties object that is specific to this UDF.
getUDFs() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.UDFFinder
 
getUdfs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerUDFCollector
 
getUid2LoadFuncMap() - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
getUidOnlySchemas() - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
getUnionMembers() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getUnionPredPlanFromSplit(PhysicalPlan, String) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.UnionOptimizer
 
getUnKnownKeys() - Method in class org.apache.pig.impl.util.UDFContextSeparator
 
getUpper() - Method in class org.apache.pig.Expression.BetweenExpression
 
getUserDefinedSchema() - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
getUserFunc() - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
getUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getValidatedProperties(Properties) - Static method in class org.apache.pig.impl.util.ConfigurationValidator
Validate properties which need to be validated and return *ONLY* those
getValInt() - Method in class org.apache.pig.tools.cmdline.CmdLineParser
Get the value, as an Integer.
getValStr() - Method in class org.apache.pig.tools.cmdline.CmdLineParser
Get the value, as a string.
getValue() - Method in interface org.apache.pig.Accumulator
Called when all tuples from current key have been passed to accumulate.
getValue() - Method in class org.apache.pig.AccumulatorEvalFunc
 
getValue() - Method in class org.apache.pig.AlgebraicEvalFunc
This function returns the ultimate result.
getValue() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getValue() - Method in class org.apache.pig.builtin.AlgebraicBigDecimalMathBase
 
getValue() - Method in class org.apache.pig.builtin.AlgebraicBigIntegerMathBase
 
getValue() - Method in class org.apache.pig.builtin.AlgebraicByteArrayMathBase
 
getValue() - Method in class org.apache.pig.builtin.AlgebraicDoubleMathBase
 
getValue() - Method in class org.apache.pig.builtin.AlgebraicFloatMathBase
 
getValue() - Method in class org.apache.pig.builtin.AlgebraicIntMathBase
 
getValue() - Method in class org.apache.pig.builtin.AlgebraicLongMathBase
 
getValue() - Method in class org.apache.pig.builtin.AVG
 
getValue() - Method in class org.apache.pig.builtin.BigDecimalAvg
 
getValue() - Method in class org.apache.pig.builtin.BigIntegerAvg
 
getValue() - Method in class org.apache.pig.builtin.COUNT
 
getValue() - Method in class org.apache.pig.builtin.COUNT_STAR
 
getValue() - Method in class org.apache.pig.builtin.DateTimeMax
 
getValue() - Method in class org.apache.pig.builtin.DateTimeMin
 
getValue() - Method in class org.apache.pig.builtin.DoubleAvg
 
getValue() - Method in class org.apache.pig.builtin.FloatAvg
 
getValue() - Method in class org.apache.pig.builtin.IntAvg
 
getValue() - Method in class org.apache.pig.builtin.LongAvg
 
getValue() - Method in class org.apache.pig.builtin.StringMax
 
getValue() - Method in class org.apache.pig.builtin.StringMin
 
getValue() - Method in class org.apache.pig.builtin.TOP
 
getValue() - Method in class org.apache.pig.Expression.Const
 
getValue() - Method in class org.apache.pig.IteratingAccumulatorEvalFunc
 
getValue() - Method in class org.apache.pig.newplan.logical.expression.ConstantExpression
Get the value of this constant.
getValue() - Method in class org.apache.pig.pen.FakeRawKeyValueIterator
 
getValue() - Method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
 
getValue() - Method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField
 
getValue() - Method in class org.apache.pig.scripting.groovy.GroovyAccumulatorEvalFunc
 
getValue() - Method in class org.apache.pig.scripting.jruby.JrubyAccumulatorEvalFunc
This method calls "get" on the AccumulatorPigUdf Ruby class that was specified.
getValue() - Method in class org.apache.pig.tools.pigstats.spark.SparkCounter
 
getValue(String, String) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounters
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableBag
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableBigDecimalWritable
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableBigIntegerWritable
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableBooleanWritable
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableBytesWritable
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableDateTimeWritable
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableDoubleWritable
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableFloatWritable
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableIntWritable
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableLongWritable
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableText
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableTuple
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableUnknownWritable
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.PigNullableWritable
 
getValueHistogram() - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
getValuePlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
getValues() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl
 
getValues() - Method in class org.apache.pig.Expression.InExpression
 
getValueTuple(PigNullableWritable, NullableTuple, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.CombinerPackager
 
getValueTuple(PigNullableWritable, NullableTuple, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.LitePackager
Makes use of the superclass method, but this requires an additional parameter key passed by ReadOnceBag.
getValueTuple(PigNullableWritable, NullableTuple, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
 
getValueTuple(PigNullableWritable, NullableTuple, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
getValueTuple(POLocalRearrange, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
getVersion() - Method in class org.apache.pig.ResourceSchema
Get the version of this schema.
getVersion() - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
getVersionString() - Static method in class org.apache.pig.Main
Returns a version string formatted similarly to that of svn.
getVertexGroup() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
getVertexGroupInfo() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getVertexGroupMembers() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getVertexGroupStores() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getVertexParallelism() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
getVertexProgress() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
getVertexStats(String) - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
getVertexStats(String, String) - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
getVertexStatus(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
getVisitor(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
Get a new instance of the expression visitor to apply to a given expression.
getVisitor(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.optimizer.ProjectionPatcher.ProjectionFinder
 
getVisitor(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.rules.ConstantCalculator.ConstantCalculatorTransformer.ConstantCalculatorLogicalPlanVisitor
 
getVisitor(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.FullMapCollector
 
getVisitor(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.MapMarker
 
getVisitor(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.visitor.CastLineageSetter
 
getVisitor(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.visitor.ColumnAliasConversionVisitor
 
getVisitor(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.visitor.ProjStarInUdfExpander
 
getVisitor(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.visitor.ScalarVisitor
 
getWarningCounters() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
GetWeek - Class in org.apache.pig.builtin
GetMonth extracts the week of a week year from a DateTime object.
GetWeek() - Constructor for class org.apache.pig.builtin.GetWeek
 
GetWeekYear - Class in org.apache.pig.builtin
GetMonth extracts the week year from a DateTime object.
GetWeekYear() - Constructor for class org.apache.pig.builtin.GetWeekYear
 
getWeightedCounts(IdentityHashSet<Tuple>, int) - Method in class org.apache.pig.impl.util.LineageTracer
 
getWeightedCounts(float, float) - Method in class org.apache.pig.pen.util.LineageTracer
 
getWrappedPigSplit() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
getWrappedPigSplit() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
getWrappedPigSplit() - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit
 
getWrappedSplit() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
This methods returns the actual InputSplit (as returned by the InputFormat) which this class is wrapping.
getWrappedSplit(int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getWrappedSplit() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
getWrappedSplit(int) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
getWrappedSplit() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
getWrappedSplit(int) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
getWrappedSplit() - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit
 
getWrappedSplit(int) - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit
 
getWritableComparable(String) - Static method in class org.apache.pig.backend.hadoop.HDataType
 
getWritableComparableTypes(Object, byte) - Static method in class org.apache.pig.backend.hadoop.HDataType
 
getWritableComparableTypes(byte) - Static method in class org.apache.pig.backend.hadoop.HDataType
 
getWriter() - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
GetYear - Class in org.apache.pig.builtin
GetYear extracts the year from a DateTime object.
GetYear() - Constructor for class org.apache.pig.builtin.GetYear
 
GFAny - Class in org.apache.pig.impl.builtin
built-in grouping function; permits system to choose any grouping.
GFAny() - Constructor for class org.apache.pig.impl.builtin.GFAny
 
GFAny(int) - Constructor for class org.apache.pig.impl.builtin.GFAny
 
GFCross - Class in org.apache.pig.impl.builtin
 
GFCross(String) - Constructor for class org.apache.pig.impl.builtin.GFCross
 
GFReplicate - Class in org.apache.pig.impl.builtin
 
GFReplicate() - Constructor for class org.apache.pig.impl.builtin.GFReplicate
 
GFReplicate(int) - Constructor for class org.apache.pig.impl.builtin.GFReplicate
 
globalCounters - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
GlobalRearrangeConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
GlobalRearrangeConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.GlobalRearrangeConverter
 
Graph(boolean) - Constructor for class org.apache.pig.PigServer.Graph
 
graphs - Variable in class org.apache.pig.PigServer
 
GreaterThanEqualExpression - Class in org.apache.pig.newplan.logical.expression
 
GreaterThanEqualExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.GreaterThanEqualExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
GreaterThanExpr - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
GreaterThanExpr(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GreaterThanExpr
 
GreaterThanExpr(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GreaterThanExpr
 
GreaterThanExpression - Class in org.apache.pig.newplan.logical.expression
 
GreaterThanExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.GreaterThanExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
GroovyAccumulatorEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAccumulatorEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAccumulatorEvalFunc
 
GroovyAlgebraicEvalFunc<T> - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc() - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc
 
GroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc
 
GroovyAlgebraicEvalFunc.AlgebraicFunctionWrapper<T> - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.BigDecimalGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.BigDecimalGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.BigIntegerGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.BigIntegerGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.BooleanGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.BooleanGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.ChararrayGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.ChararrayGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.DataBagGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
Unlike EvalFuncs and Accumulators, the type must be known at compile time (ie it can't return Object), as Pig inspects the type and ensures that it is valid.
GroovyAlgebraicEvalFunc.DataBagGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.DataByteArrayGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.DataByteArrayGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.DateTimeGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.DateTimeGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.DoubleGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.DoubleGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.Final<T> - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.FloatGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.FloatGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.Initial - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.IntegerGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.IntegerGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.Intermed - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.LongGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.LongGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.MapGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.MapGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.TupleGroovyAlgebraicEvalFunc - Class in org.apache.pig.scripting.groovy
 
GroovyAlgebraicEvalFunc.TupleGroovyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.groovy
 
GroovyEvalFunc<T> - Class in org.apache.pig.scripting.groovy
 
GroovyEvalFunc() - Constructor for class org.apache.pig.scripting.groovy.GroovyEvalFunc
 
GroovyEvalFunc(String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyEvalFunc
 
GroovyEvalFunc(String, String, String, Object) - Constructor for class org.apache.pig.scripting.groovy.GroovyEvalFunc
 
GroovyEvalFuncObject - Class in org.apache.pig.scripting.groovy
 
GroovyEvalFuncObject() - Constructor for class org.apache.pig.scripting.groovy.GroovyEvalFuncObject
 
GroovyEvalFuncObject(String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyEvalFuncObject
 
GroovyEvalFuncObject(String, String, String, Object) - Constructor for class org.apache.pig.scripting.groovy.GroovyEvalFuncObject
 
GroovyScriptEngine - Class in org.apache.pig.scripting.groovy
 
GroovyScriptEngine() - Constructor for class org.apache.pig.scripting.groovy.GroovyScriptEngine
 
groovyToPig(Object) - Static method in class org.apache.pig.scripting.groovy.GroovyUtils
Converts an object created on the Groovy side to its Pig counterpart.
GroovyUtils - Class in org.apache.pig.scripting.groovy
 
GroovyUtils() - Constructor for class org.apache.pig.scripting.groovy.GroovyUtils
 
GroovyUtils.DataBagGroovyIterator - Class in org.apache.pig.scripting.groovy
 
GroupAllParallelSetterTransformer() - Constructor for class org.apache.pig.newplan.logical.rules.GroupByConstParallelSetter.GroupAllParallelSetterTransformer
 
GroupByConstParallelSetter - Class in org.apache.pig.newplan.logical.rules
Rule: If a LOCogroup is 'group all', set the parallelism to 1, or in general - if the group-by expression is just a constant then set parallelism to 1 LogicalExpressionSimplifier could be used to convert an expression with constants into a single ConstantExpression
GroupByConstParallelSetter(String) - Constructor for class org.apache.pig.newplan.logical.rules.GroupByConstParallelSetter
 
GroupByConstParallelSetter.GroupAllParallelSetterTransformer - Class in org.apache.pig.newplan.logical.rules
 
groupDisplayName - Variable in class org.apache.pig.tools.pigstats.spark.SparkCounterGroup
 
GroupingSpillable - Interface in org.apache.pig.impl.util
Interface to be implemented by classes that group data in memory
groupName - Variable in class org.apache.pig.tools.pigstats.spark.SparkCounterGroup
 
Grunt - Class in org.apache.pig.tools.grunt
 
Grunt(BufferedReader, PigContext) - Constructor for class org.apache.pig.tools.grunt.Grunt
 
GruntParser - Class in org.apache.pig.tools.grunt
 
GruntParser(Reader) - Constructor for class org.apache.pig.tools.grunt.GruntParser
 
GruntParser(Reader, PigServer) - Constructor for class org.apache.pig.tools.grunt.GruntParser
 
GruntParser(InputStream, String) - Constructor for class org.apache.pig.tools.grunt.GruntParser
 
GruntParser(InputStream, String, PigServer) - Constructor for class org.apache.pig.tools.grunt.GruntParser
 
GruntParser(InputStream) - Constructor for class org.apache.pig.tools.grunt.GruntParser
 
GruntParser(InputStream, PigServer) - Constructor for class org.apache.pig.tools.grunt.GruntParser
 
GruntParser(PigScriptParserTokenManager) - Constructor for class org.apache.pig.tools.grunt.GruntParser
 
GruntParser(PigScriptParserTokenManager, PigServer) - Constructor for class org.apache.pig.tools.grunt.GruntParser
 
GruntParser.ExplainState - Class in org.apache.pig.tools.grunt
 
GruntParser.StreamPrinter - Class in org.apache.pig.tools.grunt
StreamPrinter.
gt_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
gt_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat
 
gt_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
gte_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
gte_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat
 
gte_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
GTOrEqualToExpr - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
GTOrEqualToExpr(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GTOrEqualToExpr
 
GTOrEqualToExpr(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GTOrEqualToExpr
 

H

HADOOP_SITE - Static variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
HadoopExecutableManager - Class in org.apache.pig.backend.hadoop.streaming
HadoopExecutableManager is a specialization of ExecutableManager and provides HDFS-specific support for secondary outputs, task-logs etc.
HadoopExecutableManager() - Constructor for class org.apache.pig.backend.hadoop.streaming.HadoopExecutableManager
 
hadoopify(String, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
hadoopVersion - Variable in class org.apache.pig.tools.pigstats.ScriptState
 
handleError(EvalFunc, Exception) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.MonitoredUDFExecutor.ErrorCallback
 
handleEvents(List<Event>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
handleNotification(Notification, Object) - Method in class org.apache.pig.impl.util.SpillableMemoryManager
 
HandlerFactory - Class in org.apache.pig.impl.streaming
Factory to create an InputHandler or OutputHandler depending on the specification of the StreamingCommand.
HandlerFactory() - Constructor for class org.apache.pig.impl.streaming.HandlerFactory
 
handleSecondarySort(<any>, POPackage) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.SecondaryKeySortUtil
 
HandleSpec(String) - Constructor for class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
Create a new StreamingCommand.HandleSpec with a given name using the default PigStorage serializer/deserializer.
HandleSpec(String, String) - Constructor for class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
Create a new StreamingCommand.HandleSpec with a given name using the default PigStorage serializer/deserializer.
handleTimeout(EvalFunc, Exception) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.MonitoredUDFExecutor.ErrorCallback
 
HangingJobKiller() - Constructor for class org.apache.pig.backend.hadoop.executionengine.Launcher.HangingJobKiller
 
hasAuthorizations(CommandLine) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
hasComparedTupleNull() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleDefaultRawComparator
 
hasComparedTupleNull() - Method in class org.apache.pig.data.BinInterSedes.BinInterSedesTupleRawComparator
 
hasComparedTupleNull() - Method in class org.apache.pig.data.DefaultTuple.DefaultTupleRawComparator
 
hasComparedTupleNull() - Method in interface org.apache.pig.data.TupleRawComparator
Checks if one of the compared tuples had a null field.
hasCompleted() - Method in interface org.apache.pig.backend.executionengine.ExecJob
true is the physical plan has executed successfully and results are ready to be retrieved
hasCompleted() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
hasError() - Method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
hasFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.LogicalExpression
This is a convenience method to avoid the side-effectful nature of getFieldSchema().
hasFlatten(LOGenerate) - Static method in class org.apache.pig.newplan.logical.rules.OptimizerUtils
Check if a given LOGenerate operator has any flatten fields.
hasFlatten(LOForEach) - Static method in class org.apache.pig.newplan.logical.rules.OptimizerUtils
Helper method to find if a given LOForEach instance contains any flatten fields.
hash(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubyDataByteArray
Overrides ruby's hash leveraging DataByteArray's hash.
hashCode() - Method in class org.apache.pig.backend.hadoop.BigDecimalWritable
 
hashCode() - Method in class org.apache.pig.backend.hadoop.BigIntegerWritable
 
hashCode() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
hashCode() - Method in class org.apache.pig.backend.hadoop.DateTimeWritable
 
hashCode() - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
hashCode() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnChainInfo
 
hashCode() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnInfo
 
hashCode() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter.InnerOperator
 
hashCode() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.IndexedKey
Calculate hashCode by index and key if key is empty, return index value if key is not empty, return the key.hashCode()
hashCode() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter.InnerOperator
 
hashCode() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerNode
 
hashCode() - Method in class org.apache.pig.backend.hadoop.hbase.TableSplitComparable
 
hashCode() - Method in class org.apache.pig.builtin.BinStorage
 
hashCode() - Method in class org.apache.pig.builtin.PigStorage
 
hashCode() - Method in class org.apache.pig.data.AccumulativeBag
 
hashCode() - Method in class org.apache.pig.data.AppendableSchemaTuple
 
hashCode() - Method in class org.apache.pig.data.DataByteArray
 
hashCode(byte[]) - Static method in class org.apache.pig.data.DataByteArray
 
hashCode() - Method in class org.apache.pig.data.DefaultAbstractBag
 
hashCode() - Method in class org.apache.pig.data.DefaultTuple
 
hashCode() - Method in class org.apache.pig.data.NonSpillableDataBag
 
hashCode() - Method in class org.apache.pig.data.ReadOnceBag
 
hashCode() - Method in class org.apache.pig.data.SchemaTuple
 
hashCode() - Method in class org.apache.pig.data.SingleTupleBag
 
hashCode() - Method in class org.apache.pig.data.TargetedTuple
 
hashCode() - Method in class org.apache.pig.data.utils.StructuresHelper.Pair
 
hashCode() - Method in class org.apache.pig.data.utils.StructuresHelper.SchemaKey
The hashcode logic is taken from the Schema class, including how fields are handled.
hashCode(Schema) - Static method in class org.apache.pig.data.utils.StructuresHelper.SchemaKey
 
hashCode() - Method in class org.apache.pig.data.utils.StructuresHelper.Triple
 
hashCode() - Method in class org.apache.pig.FileSplitComparable
 
hashCode() - Method in class org.apache.pig.FuncSpec
 
hashCode() - Method in class org.apache.pig.impl.io.FileSpec
 
hashCode() - Method in class org.apache.pig.impl.io.InterStorage
 
hashCode() - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
hashCode() - Method in class org.apache.pig.impl.io.PigNullableWritable
 
hashCode() - Method in class org.apache.pig.impl.io.TFileStorage
 
hashCode() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
 
hashCode() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
hashCode() - Method in class org.apache.pig.impl.plan.Operator
Needed to ensure that the list iterators' outputs are deterministic.
hashCode() - Method in class org.apache.pig.impl.plan.OperatorKey
 
hashCode() - Method in class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
 
hashCode() - Method in class org.apache.pig.impl.util.Pair
 
hashCode() - Method in class org.apache.pig.piggybank.storage.XMLLoader.XMLRecordReader
 
hashCode() - Method in class org.apache.pig.ResourceStatistics
 
hashCode() - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
A naive hashCode implementation following the example in IBM's developerworks: http://www.ibm.com/developerworks/java/library/j-jtp05273.html
hashCode() - Method in class org.apache.pig.SortColInfo
 
hashCode() - Method in class org.apache.pig.SortInfo
 
hashCodePiece(int, int, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
hashCodePiece(int, long, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
hashCodePiece(int, float, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
hashCodePiece(int, double, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
hashCodePiece(int, boolean, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
hashCodePiece(int, DateTime, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
hashCodePiece(int, BigDecimal, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
hashCodePiece(int, BigInteger, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
hashCodePiece(int, byte[], boolean) - Method in class org.apache.pig.data.SchemaTuple
 
hashCodePiece(int, String, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
hashCodePiece(int, Tuple, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
hashCodePiece(int, DataBag, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
hashCodePiece(int, Map<String, Object>, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
HashFNV - Class in org.apache.pig.piggybank.evaluation.string
Syntax: long HashFNV(String string_to_hash, [int mod]).
HashFNV() - Constructor for class org.apache.pig.piggybank.evaluation.string.HashFNV
 
HashFNV1 - Class in org.apache.pig.piggybank.evaluation.string
Implementation for HashFNV which takes 1 parameter
HashFNV1() - Constructor for class org.apache.pig.piggybank.evaluation.string.HashFNV1
 
HashFNV2 - Class in org.apache.pig.piggybank.evaluation.string
Implementation for HashFNV which takes 2 parameter
HashFNV2() - Constructor for class org.apache.pig.piggybank.evaluation.string.HashFNV2
 
HashOutputStream - Class in org.apache.pig.impl.util
 
HashOutputStream(HashFunction) - Constructor for class org.apache.pig.impl.util.HashOutputStream
 
hashPrime - Variable in class org.apache.pig.newplan.Operator
 
HashValuePartitioner - Class in org.apache.pig.backend.hadoop.executionengine.tez.runtime
 
HashValuePartitioner() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.runtime.HashValuePartitioner
 
hasJar(String) - Method in class org.apache.pig.impl.PigContext
 
hasLoadOrStore() - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
hasMessage() - Method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
hasMessageType(CompilationMessageCollector.MessageType) - Method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
hasNext() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl.IllustratorValueIterator
 
hasNext() - Method in class org.apache.pig.data.ReadOnceBag.ReadOnceBagIterator
 
hasNext() - Method in class org.apache.pig.impl.util.RewindableIterator
 
hasNext(int) - Method in class org.apache.pig.impl.util.RewindableIterator
 
hasNext() - Method in class org.apache.pig.scripting.groovy.GroovyUtils.DataBagGroovyIterator
 
hasNextBatch() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.AccumulativeTupleBuffer
Whether there are more tuples to pull out of iterator
hasNextBatch() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage.POPackageTupleBuffer
 
hasPrefixMatch(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage.ColumnInfo
 
HBaseBinaryConverter - Class in org.apache.pig.backend.hadoop.hbase
 
HBaseBinaryConverter() - Constructor for class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
HBaseStorage - Class in org.apache.pig.backend.hadoop.hbase
A HBase implementation of LoadFunc and StoreFunc.
HBaseStorage(String) - Constructor for class org.apache.pig.backend.hadoop.hbase.HBaseStorage
Constructor.
HBaseStorage(String, String) - Constructor for class org.apache.pig.backend.hadoop.hbase.HBaseStorage
Constructor.
HBaseStorage.ColumnInfo - Class in org.apache.pig.backend.hadoop.hbase
Class to encapsulate logic around which column names were specified in each position of the column list.
HBaseTableIFBuilder() - Constructor for class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
HBaseTableInputFormat - Class in org.apache.pig.backend.hadoop.hbase
 
HBaseTableInputFormat() - Constructor for class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat
 
HBaseTableInputFormat(long, byte[], byte[], byte[], byte[]) - Constructor for class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat
 
HBaseTableInputFormat.HBaseTableIFBuilder - Class in org.apache.pig.backend.hadoop.hbase
 
HBaseTableInputFormat.HBaseTableRecordReader - Class in org.apache.pig.backend.hadoop.hbase
 
HBaseTableRecordReader(long) - Constructor for class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableRecordReader
 
HConfiguration - Class in org.apache.pig.backend.hadoop.datastorage
 
HConfiguration() - Constructor for class org.apache.pig.backend.hadoop.datastorage.HConfiguration
 
HConfiguration(Configuration) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HConfiguration
 
HDataStorage - Class in org.apache.pig.backend.hadoop.datastorage
 
HDataStorage(URI, Properties) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
HDataStorage(Properties) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
HDataType - Class in org.apache.pig.backend.hadoop
A class of helper methods for converting from pig data types to hadoop data types, and vice versa.
HDataType() - Constructor for class org.apache.pig.backend.hadoop.HDataType
 
HDFS_BYTES_READ - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
 
HDFS_BYTES_WRITTEN - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
 
hdfsBytesRead - Variable in class org.apache.pig.tools.pigstats.JobStats
 
hdfsBytesWritten - Variable in class org.apache.pig.tools.pigstats.JobStats
 
HDirectory - Class in org.apache.pig.backend.hadoop.datastorage
 
HDirectory(HDataStorage, Path, Path) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
HDirectory(HDataStorage, String, String) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
HDirectory(HDataStorage, Path, String) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
HDirectory(HDataStorage, String, Path) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
HDirectory(HDataStorage, Path) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
HDirectory(HDataStorage, String) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
heapPerc - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
heartbeat - Variable in class org.apache.pig.data.TimestampedTuple
 
HelperClass() - Constructor for class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField.HelperClass
 
HelperClass(String) - Constructor for class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField.HelperClass
 
HelperClass(String, String) - Constructor for class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField.HelperClass
 
HExecutionEngine - Class in org.apache.pig.backend.hadoop.executionengine
 
HExecutionEngine(PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
HFile - Class in org.apache.pig.backend.hadoop.datastorage
 
HFile(HDataStorage, Path, Path) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HFile
 
HFile(HDataStorage, String, String) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HFile
 
HFile(HDataStorage, Path, String) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HFile
 
HFile(HDataStorage, String, Path) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HFile
 
HFile(HDataStorage, String) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HFile
 
HFile(HDataStorage, Path) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HFile
 
HiveColumnarLoader - Class in org.apache.pig.piggybank.storage
Loader for Hive RC Columnar files.
Supports the following types:
* Hive Type Pig Type from DataType string CHARARRAY int INTEGER bigint or long LONG float float double DOUBLE boolean BOOLEAN byte BYTE array TUPLE map MAP

Partitions
The input paths are scanned by the loader for [partition name]=[value] patterns in the subdirectories.
If detected these partitions are appended to the table schema.
For example if you have the directory structure:

HiveColumnarLoader(String) - Constructor for class org.apache.pig.piggybank.storage.HiveColumnarLoader
Table schema should be a space and comma separated string describing the Hive schema.
For example uid BIGINT, pid long, means 1 column of uid type BIGINT and one column of pid type LONG.
The types are not case sensitive.
HiveColumnarLoader(String, String, String) - Constructor for class org.apache.pig.piggybank.storage.HiveColumnarLoader
This constructor is for backward compatibility.
HiveColumnarLoader(String, String) - Constructor for class org.apache.pig.piggybank.storage.HiveColumnarLoader
This constructor is for backward compatibility.
HiveColumnarStorage - Class in org.apache.pig.piggybank.storage
 
HiveColumnarStorage() - Constructor for class org.apache.pig.piggybank.storage.HiveColumnarStorage
 
HiveRCInputFormat - Class in org.apache.pig.piggybank.storage.hiverc
HiveRCInputFormat used by HiveColumnarLoader as the InputFormat;

Reasons for implementing a new InputFormat sub class:
The current RCFileInputFormat uses the old InputFormat mapred interface, and the pig load store design used the new InputFormat mapreduce classes. The splits are calculated by the InputFormat, HiveColumnarLoader supports date partitions, the filtering is done here.

HiveRCInputFormat() - Constructor for class org.apache.pig.piggybank.storage.hiverc.HiveRCInputFormat
 
HiveRCInputFormat(String) - Constructor for class org.apache.pig.piggybank.storage.hiverc.HiveRCInputFormat
 
HiveRCOutputFormat - Class in org.apache.pig.piggybank.storage.hiverc
 
HiveRCOutputFormat() - Constructor for class org.apache.pig.piggybank.storage.hiverc.HiveRCOutputFormat
 
HiveRCOutputFormat.Writer - Class in org.apache.pig.piggybank.storage.hiverc
RecordWriter wrapper around an RCFile.Writer
HiveRCRecordReader - Class in org.apache.pig.piggybank.storage.hiverc
This class delegates the work to the RCFileRecordReader
HiveRCRecordReader() - Constructor for class org.apache.pig.piggybank.storage.hiverc.HiveRCRecordReader
 
HiveRCSchemaUtil - Class in org.apache.pig.piggybank.storage.hiverc
Implements helper methods for:
Parsing the hive table schema string. Converting from hive to pig types Converting from pig to hive types
HiveRCSchemaUtil() - Constructor for class org.apache.pig.piggybank.storage.hiverc.HiveRCSchemaUtil
 
HiveUDAF - Class in org.apache.pig.builtin
Use Hive UDAF or GenericUDAF.
HiveUDAF(String) - Constructor for class org.apache.pig.builtin.HiveUDAF
 
HiveUDAF(String, String) - Constructor for class org.apache.pig.builtin.HiveUDAF
 
HiveUDAF.Final - Class in org.apache.pig.builtin
 
HiveUDAF.Initial - Class in org.apache.pig.builtin
 
HiveUDAF.Intermediate - Class in org.apache.pig.builtin
 
HiveUDF - Class in org.apache.pig.builtin
Use Hive UDF or GenericUDF.
HiveUDF(String) - Constructor for class org.apache.pig.builtin.HiveUDF
 
HiveUDF(String, String) - Constructor for class org.apache.pig.builtin.HiveUDF
 
HiveUDTF - Class in org.apache.pig.builtin
Use Hive GenericUDTF.
HiveUDTF(String) - Constructor for class org.apache.pig.builtin.HiveUDTF
 
HiveUDTF(String, String) - Constructor for class org.apache.pig.builtin.HiveUDTF
 
HiveUtils - Class in org.apache.pig.impl.util.hive
 
HiveUtils() - Constructor for class org.apache.pig.impl.util.hive.HiveUtils
 
HiveUtils.Field - Class in org.apache.pig.impl.util.hive
 
HJob - Class in org.apache.pig.backend.hadoop.executionengine
 
HJob(ExecJob.JOB_STATUS, PigContext, POStore, String) - Constructor for class org.apache.pig.backend.hadoop.executionengine.HJob
 
HJob(ExecJob.JOB_STATUS, PigContext, POStore, String, PigStats) - Constructor for class org.apache.pig.backend.hadoop.executionengine.HJob
 
HKerberos - Class in org.apache.pig.backend.hadoop
Support for logging in using a kerberos keytab file.
HKerberos() - Constructor for class org.apache.pig.backend.hadoop.HKerberos
 
HostExtractor - Class in org.apache.pig.piggybank.evaluation.util.apachelogparser
HostExtractor takes a url and returns the host.
HostExtractor() - Constructor for class org.apache.pig.piggybank.evaluation.util.apachelogparser.HostExtractor
 
HoursBetween - Class in org.apache.pig.builtin
HoursBetween returns the number of hours between two DateTime objects
HoursBetween() - Constructor for class org.apache.pig.builtin.HoursBetween
 
HPath - Class in org.apache.pig.backend.hadoop.datastorage
 
HPath(HDataStorage, Path, Path) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HPath
 
HPath(HDataStorage, String, String) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HPath
 
HPath(HDataStorage, Path, String) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HPath
 
HPath(HDataStorage, String, Path) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HPath
 
HPath(HDataStorage, String) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HPath
 
HPath(HDataStorage, Path) - Constructor for class org.apache.pig.backend.hadoop.datastorage.HPath
 
HSeekableInputStream - Class in org.apache.pig.backend.hadoop.datastorage
 
hType - Variable in class org.apache.pig.builtin.BuildBloomBase
 
HYPOT - Class in org.apache.pig.piggybank.evaluation.math
math.HYPOT implements a binding to the Java function Math.hypot(double,double).
HYPOT() - Constructor for class org.apache.pig.piggybank.evaluation.math.HYPOT
 

I

id - Variable in class org.apache.pig.impl.plan.OperatorKey
 
id - Variable in class org.apache.pig.tools.pigstats.ScriptState
 
IdentityColumn - Class in org.apache.pig.impl.builtin
Returns the input, used by DuplicateForEachColumnRewrite to rewrite duplicate columns in ForEach.
IdentityColumn() - Constructor for class org.apache.pig.impl.builtin.IdentityColumn
 
IdentityHashSet<E> - Class in org.apache.pig.impl.util
 
IdentityHashSet() - Constructor for class org.apache.pig.impl.util.IdentityHashSet
 
idxSpace - Static variable in class org.apache.pig.impl.io.PigNullableWritable
regular indices used in group and cogroup can only go from 0x00 to 0x7F
IEEEremainder - Class in org.apache.pig.piggybank.evaluation.math
math.IEEEremainder implements a binding to the Java function Math.IEEEremainder(double,double).
IEEEremainder() - Constructor for class org.apache.pig.piggybank.evaluation.math.IEEEremainder
 
ignoreWhitespace - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
ILLEGAL_ARGS - Static variable in class org.apache.pig.PigRunner.ReturnCode
 
Illustrable - Interface in org.apache.pig.pen
 
illustrate() - Method in class org.apache.pig.scripting.BoundScript
Run illustrate for this pipeline.
IllustrateDummyReporter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Dummy implementation of StatusReporter for illustrate mode
IllustrateDummyReporter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.IllustrateDummyReporter
 
illustrator - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
illustrator - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
Illustrator - Class in org.apache.pig.pen
Class used by physical operators to generate example tuples for the ILLUSTRATE purpose
Illustrator(LineageTracer, LinkedList<IdentityHashSet<Tuple>>, IllustratorAttacher, PigContext) - Constructor for class org.apache.pig.pen.Illustrator
 
Illustrator(LineageTracer, LinkedList<IdentityHashSet<Tuple>>, int, IllustratorAttacher, LogicalSchema, PigContext) - Constructor for class org.apache.pig.pen.Illustrator
 
IllustratorAttacher - Class in org.apache.pig.pen
The class used to (re)attach illustrators to physical operators
IllustratorAttacher(PhysicalPlan, LineageTracer, int, Map<POLoad, LogicalSchema>, PigContext) - Constructor for class org.apache.pig.pen.IllustratorAttacher
 
IllustratorContext(Configuration, DataBag, List<Pair<PigNullableWritable, Writable>>, InputSplit) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase.IllustratorContext
 
IllustratorContextImpl(Job, List<Pair<PigNullableWritable, Writable>>, POPackage) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryComparisonOperator
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryComparisonOperator
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.LitePackager
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POBroadcastSpark
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PONative
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage.POPackageTupleBuffer
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POReservoirSample
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POJoinGroupSpark
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POSampleSortSpark
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffledValueInputTez
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueInputTez
 
illustratorMarkup(Object, Object, int) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
illustratorMarkup(Object, Object, int) - Method in interface org.apache.pig.pen.Illustrable
input tuple mark up to be illustrate-able
illustratorMarkup2(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
IllustratorValueIterable() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl.IllustratorValueIterable
 
IllustratorValueIterator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl.IllustratorValueIterator
 
ImmutableOutputStream - Class in org.apache.pig.backend.datastorage
 
ImmutableOutputStream(String) - Constructor for class org.apache.pig.backend.datastorage.ImmutableOutputStream
 
ImplicitSplitInsertVisitor - Class in org.apache.pig.newplan.logical.visitor
 
ImplicitSplitInsertVisitor(LogicalPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.ImplicitSplitInsertVisitor
 
in - Variable in class org.apache.pig.builtin.OrcStorage
 
in - Variable in class org.apache.pig.builtin.PigStorage
 
in - Variable in class org.apache.pig.builtin.TextLoader
 
in - Variable in class org.apache.pig.impl.streaming.OutputHandler
 
in - Variable in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
in - Variable in class org.apache.pig.piggybank.storage.CSVLoader
 
in - Variable in class org.apache.pig.piggybank.storage.XMLLoader
Underlying record reader
incrCounter(Enum<?>, long) - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchTaskContext
 
incrCounter(String, String, long) - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchTaskContext
 
incrCounter(Enum<?>, long) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRTaskContext
 
incrCounter(String, String, long) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRTaskContext
 
incrCounter(Enum<?>, long) - Method in class org.apache.pig.backend.hadoop.executionengine.TaskContext
 
incrCounter(String, String, long) - Method in class org.apache.pig.backend.hadoop.executionengine.TaskContext
 
incrCounter(Enum<?>, long) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezTaskContext
 
incrCounter(String, String, long) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezTaskContext
 
incrCounter(String, String, long) - Method in class org.apache.pig.tools.counters.PigCounterHelper
Mocks the Reporter.incrCounter, but adds buffering.
incrCounter(Enum<?>, long) - Method in class org.apache.pig.tools.counters.PigCounterHelper
Mocks the Reporter.incrCounter, but adds buffering.
incrCounter(Enum<?>, long) - Method in class org.apache.pig.tools.pigstats.PigStatusReporter
 
incrCounter(String, String, long) - Method in class org.apache.pig.tools.pigstats.PigStatusReporter
 
increment(T) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounter
 
increment(Enum<?>, long) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounters
 
increment(String, String, long) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounters
 
incrementCounter(Long) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter.PigReduceCounter
On this case, global counters are accessed during reduce phase (immediately after a sorting phase) and the increment for global counters are dependent if it is dense rank or not.
incrementLocalCounter() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
Sequential counter used at ROW NUMBER and RANK BY DENSE mode
incrementNumDistinctChanged() - Method in class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil.SecondaryKeyOptimizerInfo
 
incrementNumSortRemoved() - Method in class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil.SecondaryKeyOptimizerInfo
 
incrementNumUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil.SecondaryKeyOptimizerInfo
 
incrementReduceCounter(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
incrementReduceCounter(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterTez
 
incrRecordCounter(String, long) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReducePOStoreImpl
 
incrWarnCounter(Enum<?>, Object) - Method in class org.apache.pig.tools.pigstats.PigStatusReporter
 
incrWarnCounter(String, String, Object) - Method in class org.apache.pig.tools.pigstats.PigStatusReporter
 
incrWarnCounter(Enum<?>, Object) - Method in interface org.apache.pig.tools.pigstats.PigWarnCounter
 
incrWarnCounter(String, String, Object) - Method in interface org.apache.pig.tools.pigstats.PigWarnCounter
 
incrWarnCounter(Enum<?>, Object) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounters
 
incrWarnCounter(String, String, Object) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounters
 
incSpillCount(Enum) - Method in class org.apache.pig.data.DefaultAbstractBag
 
incSpillCount(Enum, long) - Method in class org.apache.pig.data.DefaultAbstractBag
 
index - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
index(ThreadContext, IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubySchema
Given a field name, this will return the index of it in the schema.
IndexableLoadFunc - Interface in org.apache.pig
This class is intended for use by LoadFunc implementations which have an internal index for sorted data and can use the index to support merge join in Pig.
IndexedKey - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
IndexedKey records the index and key info.
IndexedKey(byte, Object) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.IndexedKey
 
IndexedStorage - Class in org.apache.pig.piggybank.storage
IndexedStorage is a form of PigStorage that supports a per record seek.
IndexedStorage(String, String) - Constructor for class org.apache.pig.piggybank.storage.IndexedStorage
Constructs a Pig Storer that uses specified regex as a field delimiter.
IndexedStorage.IndexedStorageInputFormat - Class in org.apache.pig.piggybank.storage
Internal InputFormat class
IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader - Class in org.apache.pig.piggybank.storage
Internal RecordReader class
IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.IndexedStorageLineReader - Class in org.apache.pig.piggybank.storage
 
IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.IndexedStorageRecordReaderComparator - Class in org.apache.pig.piggybank.storage
Class to compare record readers using underlying indexes
IndexedStorage.IndexedStorageOutputFormat - Class in org.apache.pig.piggybank.storage
Internal OutputFormat class
IndexedStorage.IndexedStorageOutputFormat.IndexedStorageRecordWriter - Class in org.apache.pig.piggybank.storage
Internal class to do the actual record writing and index generation
IndexedStorage.IndexManager - Class in org.apache.pig.piggybank.storage
IndexManager manages the index file (both writing and reading) It keeps track of the last index read during reading.
IndexedStorageInputFormat() - Constructor for class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat
 
IndexedStorageLineReader(InputStream) - Constructor for class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.IndexedStorageLineReader
Create a line reader that reads from the given stream using the default buffer-size (64k).
IndexedStorageLineReader(InputStream, int) - Constructor for class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.IndexedStorageLineReader
Create a line reader that reads from the given stream using the given buffer-size.
IndexedStorageLineReader(InputStream, Configuration) - Constructor for class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.IndexedStorageLineReader
Create a line reader that reads from the given stream using the io.file.buffer.size specified in the given Configuration.
IndexedStorageOutputFormat(byte, int[]) - Constructor for class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageOutputFormat
 
IndexedStorageRecordReader(IndexedStorage.IndexManager) - Constructor for class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader
 
IndexedStorageRecordReaderComparator() - Constructor for class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.IndexedStorageRecordReaderComparator
 
IndexedStorageRecordWriter(FSDataOutputStream, byte, IndexedStorage.IndexManager) - Constructor for class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageOutputFormat.IndexedStorageRecordWriter
 
IndexHelper(List<E>) - Constructor for class org.apache.pig.impl.plan.OperatorPlan.IndexHelper
 
IndexManager(FileStatus) - Constructor for class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Constructor (called during reading)
IndexManager(int[]) - Constructor for class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Constructor (called during writing)
INDEXOF - Class in org.apache.pig.builtin
INDEXOF implements eval function to search for a string Example: A = load 'mydata' as (name); B = foreach A generate INDEXOF(name, ",");
INDEXOF() - Constructor for class org.apache.pig.builtin.INDEXOF
 
INDEXOF - Class in org.apache.pig.piggybank.evaluation.string
Deprecated.
INDEXOF() - Constructor for class org.apache.pig.piggybank.evaluation.string.INDEXOF
Deprecated.
 
inDumpSchema - Variable in class org.apache.pig.impl.PigContext
 
inEdges - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
inExplain - Variable in class org.apache.pig.impl.PigContext
 
InExpression(List<Object>) - Constructor for class org.apache.pig.Expression.InExpression
 
inferPigDataType(Type) - Method in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
INFO - Static variable in class org.apache.pig.piggybank.storage.avro.AvroStorageLog
 
inheritSchema(LogicalExpression) - Method in class org.apache.pig.newplan.logical.expression.ConstantExpression
 
inIllustrator(Mapper<Text, Tuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
 
inIllustrator(Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
 
inIllustrator(Mapper<Text, Tuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
 
inIllustrator(Reducer.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
 
inIllustrator - Variable in class org.apache.pig.impl.PigContext
 
init() - Method in interface org.apache.pig.backend.datastorage.DataStorage
Place holder for possible initialization activities.
init() - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
This method is responsible for the initialization of the ExecutionEngine.
init() - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
init() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
init() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SkewedPartitioner
 
init() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
init() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.IsFirstReduceOfKeyTez
 
init() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.SkewedPartitionerTez
 
init() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.WeightedRangePartitionerTez
 
init(PigContext, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezResourceManager
 
init() - Method in class org.apache.pig.impl.builtin.IsFirstReduceOfKey
 
init() - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
init(Tuple) - Method in class org.apache.pig.piggybank.evaluation.string.LookupInFiles
 
init(String, Schema, boolean) - Method in class org.apache.pig.piggybank.storage.avro.AvroSchemaManager
Initialize given a schema
init(Map<String, Object>) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
Initialize output avro schema using input property map
inited - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SkewedPartitioner
 
inited - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
INITIAL - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
Initial() - Constructor for class org.apache.pig.builtin.AlgebraicByteArrayMathBase.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.AVG.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.BigDecimalAvg.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.BigIntegerAvg.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.BuildBloom.Initial
 
Initial(String, String, String, String) - Constructor for class org.apache.pig.builtin.BuildBloom.Initial
 
Initial(String, String, String) - Constructor for class org.apache.pig.builtin.BuildBloom.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.COR.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.COUNT.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.COUNT_STAR.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.COV.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.DateTimeMax.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.DateTimeMin.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.Distinct.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.DoubleAvg.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.FloatAvg.Initial
 
Initial(String) - Constructor for class org.apache.pig.builtin.HiveUDAF.Initial
 
Initial(String, String) - Constructor for class org.apache.pig.builtin.HiveUDAF.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.IntAvg.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.LongAvg.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.StringMax.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.StringMin.Initial
 
Initial() - Constructor for class org.apache.pig.builtin.TOP.Initial
 
Initial(String) - Constructor for class org.apache.pig.builtin.TOP.Initial
 
Initial() - Constructor for class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField.Initial
 
Initial() - Constructor for class org.apache.pig.piggybank.evaluation.stats.COR.Initial
Deprecated.
 
Initial() - Constructor for class org.apache.pig.piggybank.evaluation.stats.COV.Initial
Deprecated.
 
Initial() - Constructor for class org.apache.pig.piggybank.evaluation.util.Top.Initial
Deprecated.
 
Initial() - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.Initial
 
Initial(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.Initial
 
Initial() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.Initial
 
Initial(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.Initial
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigRecordReader
 
initialize(ProcessorContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterTez
 
initialize(ProcessorContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POSimpleTezLoad
 
initialize(ProcessorContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POStoreTez
 
initialize(ProcessorContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
initialize() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PartitionerDefinedVertexManager
 
initialize() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigGraceShuffleVertexManager
 
initialize() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
initialize(ProcessorContext) - Method in interface org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezTaskConfigurable
 
initialize() - Method in class org.apache.pig.builtin.InvokerGenerator
 
initialize(Configuration, PigContext) - Static method in class org.apache.pig.data.SchemaTupleBackend
 
initialize(Configuration) - Static method in class org.apache.pig.data.SchemaTupleBackend
 
initialize(Configuration, boolean) - Static method in class org.apache.pig.data.SchemaTupleBackend
 
initialize(Configuration) - Method in class org.apache.pig.impl.builtin.DefaultIndexableLoader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.impl.io.BinStorageRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.impl.io.InterRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.impl.io.TFileRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.impl.util.avro.AvroArrayReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.impl.util.avro.AvroRecordReader
 
initialize(Configuration) - Method in interface org.apache.pig.IndexableLoadFunc
This method is called by Pig run time to allow the IndexableLoadFunc to perform any initialization actions
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.AllLoader.AllReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader
 
initialize(Configuration) - Method in class org.apache.pig.piggybank.storage.IndexedStorage
IndexableLoadFunc interface implementation
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.pig.piggybank.storage.XMLLoader.XMLRecordReader
Delegate the initialization method to the wrapped stream after changing the length of the split to be non-ending.
initialize() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
initialize() - Method in class org.apache.pig.scripting.jruby.RubyDataBag
The initialize method is the method used on the Ruby side to construct the RubyDataBag object.
initialize(IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubyDataBag
The initialize method can optionally receive a DataBag.
initialize() - Method in class org.apache.pig.scripting.jruby.RubyDataByteArray
This is the default initializer, which returns an empty DataByteArray.
initialize(IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubyDataByteArray
Given a String or a set of bytes[], initializes the encapsulated DataByteArray using DataByteArray.set(byte[]).
initialize(IRubyObject, IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubyDataByteArray
Given two RubyDataByteArrays, initializes the encapsulated DataByteArray to be a concatentation of the copied bits of the first and second.
initialize(IRubyObject[]) - Method in class org.apache.pig.scripting.jruby.RubySchema
The ruby initializer accepts any number of arguments.
initialize(PigContext, SparkOperPlan, Configuration) - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
initialize(TezPlanContainer) - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
initialized - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
 
initialized - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
initializeImportList(String) - Static method in class org.apache.pig.impl.PigContext
 
initialPlanNotification(String, OperatorPlan<?>) - Method in interface org.apache.pig.tools.pigstats.PigProgressNotificationListener
Invoked before any Hadoop jobs (or a Tez DAG) are run with the plan that is to be executed.
initNextRecordReader() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigRecordReader
Get the record reader for the next chunk in this CombineFileSplit.
initWarningCounters() - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
InnerOperator(PhysicalPlan, String) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter.InnerOperator
 
InnerOperator(PhysicalPlan, String) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter.InnerOperator
 
InnerPlan(PhysicalPlan, PhysicalPlan, PhysicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter.InnerPlan
 
InnerPlan(PhysicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter.InnerPlan
 
inp - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
inProcessing() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
inpTuple - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
input - Variable in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
input - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
INPUT - Static variable in exception org.apache.pig.PigException
 
INPUT_AVRO_SCHEMA - Static variable in class org.apache.pig.builtin.AvroStorage
Pig property name for the input avro schema.
INPUT_DIR - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
INPUT_DIR_RECURSIVE - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
inputAttached - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
inputBags - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
inputBytes - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
inputClassName - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
inputFormat - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat.RecordReaderFactory
 
INPUTFORMAT_CLASS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
InputHandler - Class in org.apache.pig.impl.streaming
InputHandler is responsible for handling the input to the Pig-Streaming external command.
InputHandler() - Constructor for class org.apache.pig.impl.streaming.InputHandler
 
InputHandler.InputType - Enum in org.apache.pig.impl.streaming
 
inputKeys - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffleTezLoad
 
InputOutputFileValidatorVisitor - Class in org.apache.pig.newplan.logical.visitor
 
InputOutputFileValidatorVisitor(OperatorPlan, PigContext) - Constructor for class org.apache.pig.newplan.logical.visitor.InputOutputFileValidatorVisitor
 
inputPlans - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
inputRecords - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
inputs - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
inputs - Variable in class org.apache.pig.tools.pigstats.JobStats
 
inputSchemas - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
InputSizeReducerEstimator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Class that estimates the number of reducers based on input size.
InputSizeReducerEstimator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.InputSizeReducerEstimator
 
inputSplitToString(InputSplit[]) - Method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
 
InputStats - Class in org.apache.pig.tools.pigstats
This class encapsulates the runtime statistics of a user specified input.
InputStats(String, long, long, boolean) - Constructor for class org.apache.pig.tools.pigstats.InputStats
 
InputStats.INPUT_TYPE - Enum in org.apache.pig.tools.pigstats
 
INPUTUIDS - Static variable in class org.apache.pig.newplan.logical.rules.ColumnPruneHelper
 
insert(List<Integer>, byte) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnChainInfo
 
insert(int, byte) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnChainInfo
Insert new ColumnInfo for a project-star or project-range-to-end
insert(Tuple) - Method in class org.apache.pig.impl.util.LineageTracer
 
insert(Tuple) - Method in class org.apache.pig.pen.util.LineageTracer
 
INSERT_ENABLED - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
use PigConfiguration.PIG_SCRIPT_INFO_ENABLED instead. Will be removed in Pig 0.16
insertBetween(E, E, E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Given two connected nodes add another node between them.
insertBetween(Operator, Operator, Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
 
insertBetween(Operator, Operator, Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
This method insert node operatorToInsert between pred and succ.
insertBetween(Operator, Operator, Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
insertColumnChainInfo(ColumnChainInfo) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnChainInfo
 
insertColumnChainInfo(int, ColumnChainInfo, boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SortKeyInfo
 
insertInReduce(POProject) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnChainInfo
 
inspect(ThreadContext, IRubyObject[]) - Method in class org.apache.pig.scripting.jruby.RubyDataBag
This method returns a string representation of the RubyDataBag.
inst - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
instanceOf(Schema, Object) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
Recursively check whether "datum" is an instance of "schema" and called by PigAvroDatumWriter.resolveUnionSchema(Schema,Object), PigAvroDatumWriter.unwrappedInstanceOf(Schema,Object).
instantiateFuncFromAlias(String) - Method in class org.apache.pig.impl.PigContext
 
instantiateFuncFromSpec(FuncSpec) - Static method in class org.apache.pig.impl.PigContext
 
instantiateFuncFromSpec(String) - Static method in class org.apache.pig.impl.PigContext
 
instantiateObjectFromParams(Configuration, String, String, Class<T>) - Static method in class org.apache.pig.impl.PigContext
A common Pig pattern for initializing objects via system properties is to support passing something like this on the command line: -Dpig.notification.listener=MyClass -Dpig.notification.listener.arg=myConstructorStringArg This method will properly initialize the class with the args, if they exist.
instantiatePigStats() - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Creates a PigStats object which will be accessible as a ThreadLocal variable inside the PigStats class.
instantiatePigStats() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRExecutionEngine
 
instantiatePigStats() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkExecutionEngine
 
instantiatePigStats() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezExecutionEngine
 
instantiateScriptState() - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Creates a ScriptState object which will be accessible as a ThreadLocal variable inside the ScriptState class.
instantiateScriptState() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRExecutionEngine
 
instantiateScriptState() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkExecutionEngine
 
instantiateScriptState() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezExecutionEngine
 
IntAbs - Class in org.apache.pig.builtin
ABS implements a binding to the Java function Math.abs(int) for computing the absolute value of the argument.
IntAbs() - Constructor for class org.apache.pig.builtin.IntAbs
 
IntAbs - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use IntAbs
IntAbs() - Constructor for class org.apache.pig.piggybank.evaluation.math.IntAbs
Deprecated.
 
IntAvg - Class in org.apache.pig.builtin
This method should never be used directly, use AVG.
IntAvg() - Constructor for class org.apache.pig.builtin.IntAvg
 
IntAvg.Final - Class in org.apache.pig.builtin
 
IntAvg.Initial - Class in org.apache.pig.builtin
 
IntAvg.Intermediate - Class in org.apache.pig.builtin
 
INTEGER - Static variable in class org.apache.pig.data.BinInterSedes
 
INTEGER - Static variable in class org.apache.pig.data.DataType
 
INTEGER_0 - Static variable in class org.apache.pig.data.BinInterSedes
 
INTEGER_1 - Static variable in class org.apache.pig.data.BinInterSedes
 
INTEGER_INBYTE - Static variable in class org.apache.pig.data.BinInterSedes
 
INTEGER_INSHORT - Static variable in class org.apache.pig.data.BinInterSedes
 
IntegerGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.IntegerGroovyAlgebraicEvalFunc
 
IntegerJrubyAlgebraicEvalFunc(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.IntegerJrubyAlgebraicEvalFunc
 
InterfaceAudience - Class in org.apache.pig.classification
Annotation to inform users of a package, class or method's intended audience.
InterfaceAudience.LimitedPrivate - Annotation Type in org.apache.pig.classification
Intended only for the project(s) specified in the annotation
InterfaceAudience.Private - Annotation Type in org.apache.pig.classification
Intended for use only within Pig itself.
InterfaceAudience.Public - Annotation Type in org.apache.pig.classification
Intended for use by any project or application.
InterfaceStability - Class in org.apache.pig.classification
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
InterfaceStability() - Constructor for class org.apache.pig.classification.InterfaceStability
 
InterfaceStability.Evolving - Annotation Type in org.apache.pig.classification
Evolving, but can break compatibility at minor release (i.e.
InterfaceStability.Stable - Annotation Type in org.apache.pig.classification
Can evolve while retaining compatibility for minor release boundaries.; can break compatibility only at major release (ie.
InterfaceStability.Unstable - Annotation Type in org.apache.pig.classification
No guarantee is provided as to reliability or stability across any level of release granularity.
InterInputFormat() - Constructor for class org.apache.pig.impl.io.InterStorage.InterInputFormat
 
Intermed() - Constructor for class org.apache.pig.builtin.COR.Intermed
 
Intermed() - Constructor for class org.apache.pig.builtin.COV.Intermed
 
Intermed() - Constructor for class org.apache.pig.builtin.TOP.Intermed
 
Intermed(String) - Constructor for class org.apache.pig.builtin.TOP.Intermed
 
Intermed() - Constructor for class org.apache.pig.piggybank.evaluation.stats.COR.Intermed
Deprecated.
 
Intermed() - Constructor for class org.apache.pig.piggybank.evaluation.stats.COV.Intermed
Deprecated.
 
Intermed() - Constructor for class org.apache.pig.piggybank.evaluation.util.Top.Intermed
Deprecated.
 
Intermed() - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.Intermed
 
Intermed(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.Intermed
 
Intermed() - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.Intermed
 
Intermed(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.Intermed
 
INTERMEDIATE - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
Intermediate() - Constructor for class org.apache.pig.builtin.AlgebraicBigDecimalMathBase.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.AlgebraicBigIntegerMathBase.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.AlgebraicByteArrayMathBase.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.AlgebraicDoubleMathBase.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.AlgebraicFloatMathBase.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.AlgebraicIntMathBase.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.AlgebraicLongMathBase.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.AVG.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.BigDecimalAvg.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.BigDecimalMax.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.BigDecimalMin.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.BigDecimalSum.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.BigIntegerAvg.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.BigIntegerMax.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.BigIntegerMin.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.BigIntegerSum.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.BuildBloom.Intermediate
 
Intermediate(String, String, String, String) - Constructor for class org.apache.pig.builtin.BuildBloom.Intermediate
 
Intermediate(String, String, String) - Constructor for class org.apache.pig.builtin.BuildBloom.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.COUNT.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.COUNT_STAR.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.DateTimeMax.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.DateTimeMin.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.Distinct.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.DoubleAvg.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.DoubleMax.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.DoubleMin.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.DoubleSum.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.FloatAvg.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.FloatMax.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.FloatMin.Intermediate
 
Intermediate(String) - Constructor for class org.apache.pig.builtin.HiveUDAF.Intermediate
 
Intermediate(String, String) - Constructor for class org.apache.pig.builtin.HiveUDAF.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.IntAvg.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.IntMax.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.IntMin.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.LongAvg.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.LongMax.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.LongMin.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.LongSum.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.MAX.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.MIN.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.StringMax.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.StringMin.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.builtin.SUM.Intermediate
 
Intermediate() - Constructor for class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField.Intermediate
 
InternalCachedBag - Class in org.apache.pig.data
 
InternalCachedBag() - Constructor for class org.apache.pig.data.InternalCachedBag
 
InternalCachedBag(int) - Constructor for class org.apache.pig.data.InternalCachedBag
 
InternalCachedBag(int, float) - Constructor for class org.apache.pig.data.InternalCachedBag
 
InternalDistinctBag - Class in org.apache.pig.data
An unordered collection of Tuples with no multiples.
InternalDistinctBag() - Constructor for class org.apache.pig.data.InternalDistinctBag
 
InternalDistinctBag(int) - Constructor for class org.apache.pig.data.InternalDistinctBag
 
InternalDistinctBag(int, float) - Constructor for class org.apache.pig.data.InternalDistinctBag
 
INTERNALMAP - Static variable in class org.apache.pig.data.BinInterSedes
 
INTERNALMAP - Static variable in class org.apache.pig.data.DataType
Internal use only.
InternalMap - Class in org.apache.pig.data
This class is an empty extension of Map.
InternalMap() - Constructor for class org.apache.pig.data.InternalMap
 
InternalMap(int) - Constructor for class org.apache.pig.data.InternalMap
 
InternalSortedBag - Class in org.apache.pig.data
An ordered collection of Tuples (possibly) with multiples.
InternalSortedBag() - Constructor for class org.apache.pig.data.InternalSortedBag
 
InternalSortedBag(Comparator<Tuple>) - Constructor for class org.apache.pig.data.InternalSortedBag
 
InternalSortedBag(int, Comparator<Tuple>) - Constructor for class org.apache.pig.data.InternalSortedBag
 
InternalSortedBag(int, float, Comparator<Tuple>) - Constructor for class org.apache.pig.data.InternalSortedBag
 
InterOutputFormat() - Constructor for class org.apache.pig.impl.io.InterStorage.InterOutputFormat
 
InterRecordReader - Class in org.apache.pig.impl.io
A record reader used to read data written using InterRecordWriter It uses the default InterSedes object for deserialization.
InterRecordReader() - Constructor for class org.apache.pig.impl.io.InterRecordReader
 
InterRecordWriter - Class in org.apache.pig.impl.io
A record reader used to write data compatible with InterRecordWriter It uses the default InterSedes object for serialization.
InterRecordWriter(DataOutputStream) - Constructor for class org.apache.pig.impl.io.InterRecordWriter
 
InterSedes - Interface in org.apache.pig.data
A class to handle reading and writing of intermediate results of data types.
InterSedesFactory - Class in org.apache.pig.data
Used to get hold of the single instance of InterSedes .
InterSedesFactory() - Constructor for class org.apache.pig.data.InterSedesFactory
 
InterStorage - Class in org.apache.pig.impl.io
LOAD FUNCTION FOR PIG INTERNAL USE ONLY! This load function is used for storing intermediate data between MR jobs of a pig query.
InterStorage() - Constructor for class org.apache.pig.impl.io.InterStorage
Simple binary nested reader format
InterStorage.InterInputFormat - Class in org.apache.pig.impl.io
 
InterStorage.InterOutputFormat - Class in org.apache.pig.impl.io
 
IntMax - Class in org.apache.pig.builtin
This method should never be used directly, use MAX.
IntMax() - Constructor for class org.apache.pig.builtin.IntMax
 
IntMax - Class in org.apache.pig.piggybank.evaluation.math
math.max implements a binding to the Java function Math.max(int,int) for computing the the max value of the arguments.
IntMax() - Constructor for class org.apache.pig.piggybank.evaluation.math.IntMax
 
IntMax.Final - Class in org.apache.pig.builtin
 
IntMax.Intermediate - Class in org.apache.pig.builtin
 
IntMin - Class in org.apache.pig.builtin
This method should never be used directly, use MIN.
IntMin() - Constructor for class org.apache.pig.builtin.IntMin
 
IntMin - Class in org.apache.pig.piggybank.evaluation.math
math.min implements a binding to the Java function Math.min(int,int) for computing the the min value of the arguments.
IntMin() - Constructor for class org.apache.pig.piggybank.evaluation.math.IntMin
 
IntMin.Final - Class in org.apache.pig.builtin
 
IntMin.Intermediate - Class in org.apache.pig.builtin
 
IntSchema - Static variable in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
 
IntSum - Class in org.apache.pig.builtin
This method should never be used directly, use SUM.
IntSum() - Constructor for class org.apache.pig.builtin.IntSum
 
inTypeClass - Variable in class org.apache.pig.PrimitiveEvalFunc
 
InvalidCommandException - Exception in org.apache.pig.parser
 
InvalidCommandException(IntStream, SourceLocation, String) - Constructor for exception org.apache.pig.parser.InvalidCommandException
 
InvalidPathException - Exception in org.apache.pig.parser
 
InvalidPathException(IntStream, SourceLocation, MalformedURLException) - Constructor for exception org.apache.pig.parser.InvalidPathException
 
InvalidScalarProjectionException - Exception in org.apache.pig.parser
 
InvalidScalarProjectionException(IntStream, SourceLocation, ScalarExpression) - Constructor for exception org.apache.pig.parser.InvalidScalarProjectionException
 
InvalidScalarProjectionException(IntStream, SourceLocation, ScalarExpression, String) - Constructor for exception org.apache.pig.parser.InvalidScalarProjectionException
Constructor that takes an additional string to be concatenated with the exception message
INVERSEMAP - Class in org.apache.pig.builtin
This UDF accepts a Map as input with values of any primitive data type.
INVERSEMAP() - Constructor for class org.apache.pig.builtin.INVERSEMAP
 
InvocationPoint(int, String, String) - Constructor for class org.apache.pig.parser.PigParserNode.InvocationPoint
 
invoke(Tuple) - Method in class org.apache.pig.builtin.Invoker
 
InvokeForDouble - Class in org.apache.pig.builtin
 
InvokeForDouble() - Constructor for class org.apache.pig.builtin.InvokeForDouble
 
InvokeForDouble(String) - Constructor for class org.apache.pig.builtin.InvokeForDouble
 
InvokeForDouble(String, String) - Constructor for class org.apache.pig.builtin.InvokeForDouble
 
InvokeForDouble(String, String, String) - Constructor for class org.apache.pig.builtin.InvokeForDouble
 
InvokeForFloat - Class in org.apache.pig.builtin
 
InvokeForFloat() - Constructor for class org.apache.pig.builtin.InvokeForFloat
 
InvokeForFloat(String) - Constructor for class org.apache.pig.builtin.InvokeForFloat
 
InvokeForFloat(String, String) - Constructor for class org.apache.pig.builtin.InvokeForFloat
 
InvokeForFloat(String, String, String) - Constructor for class org.apache.pig.builtin.InvokeForFloat
 
InvokeForInt - Class in org.apache.pig.builtin
 
InvokeForInt() - Constructor for class org.apache.pig.builtin.InvokeForInt
 
InvokeForInt(String, String) - Constructor for class org.apache.pig.builtin.InvokeForInt
 
InvokeForInt(String) - Constructor for class org.apache.pig.builtin.InvokeForInt
 
InvokeForInt(String, String, String) - Constructor for class org.apache.pig.builtin.InvokeForInt
 
InvokeForLong - Class in org.apache.pig.builtin
 
InvokeForLong() - Constructor for class org.apache.pig.builtin.InvokeForLong
 
InvokeForLong(String) - Constructor for class org.apache.pig.builtin.InvokeForLong
 
InvokeForLong(String, String) - Constructor for class org.apache.pig.builtin.InvokeForLong
 
InvokeForLong(String, String, String) - Constructor for class org.apache.pig.builtin.InvokeForLong
 
InvokeForString - Class in org.apache.pig.builtin
 
InvokeForString() - Constructor for class org.apache.pig.builtin.InvokeForString
 
InvokeForString(String, String) - Constructor for class org.apache.pig.builtin.InvokeForString
 
InvokeForString(String) - Constructor for class org.apache.pig.builtin.InvokeForString
 
InvokeForString(String, String, String) - Constructor for class org.apache.pig.builtin.InvokeForString
 
Invoker<T> - Class in org.apache.pig.builtin
 
Invoker(String, String) - Constructor for class org.apache.pig.builtin.Invoker
 
Invoker(String, String, String) - Constructor for class org.apache.pig.builtin.Invoker
 
InvokerFunction - Interface in org.apache.pig.builtin
 
InvokerGenerator - Class in org.apache.pig.builtin
 
InvokerGenerator(String, String, String) - Constructor for class org.apache.pig.builtin.InvokerGenerator
 
IO_EXCEPTION - Static variable in class org.apache.pig.PigRunner.ReturnCode
 
IO_SORT_MB - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
is64bitJVM() - Static method in class org.apache.pig.impl.util.Utils
 
isAcceptableUnion(Schema) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
determine whether a union is a nullable union; note that this function doesn't check containing types of the input union recursively.
isAccumStarted() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
isAccumulative() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
isAppendedFieldsNull() - Method in class org.apache.pig.data.AppendableSchemaTuple
 
isAsynchronous() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
isAsynchronous() - Method in class org.apache.pig.EvalFunc
Deprecated.
isAtomic(byte) - Static method in class org.apache.pig.data.DataType
Determine whether the this data type is atomic.
isAtomic(Object) - Static method in class org.apache.pig.data.DataType
Determine whether the this data type is atomic.
isBatchEmpty() - Method in class org.apache.pig.PigServer
Returns whether there is anything to process in the current batch.
isBatchOn() - Method in class org.apache.pig.PigServer
Retrieve the current execution mode.
isBlocking() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
A blocking operator should override this to return true.
isBlocking() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
isBlocking() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
isBlocking() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
isBug(byte) - Static method in exception org.apache.pig.PigException
A static method to query if an error source is due to a bug or not.
isBuildBloom() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isCastAdjusted() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
isCastAdjusted() - Method in class org.apache.pig.newplan.logical.relational.LOStream
 
isCastAdjusted(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.rules.LoadTypeCastInserter
 
isCastAdjusted(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.rules.StreamTypeCastInserter
 
isCastAdjusted(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.rules.TypeCastInserter
 
isClassCapturingOutput() - Static method in class org.apache.pig.scripting.ScriptingOutputCapturer
 
isClosed() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isCogroup() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isCogroup() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
isCogroup() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isColumnMap() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage.ColumnInfo
 
isCompatible(Schema, ResourceSchema.ResourceFieldSchema) - Static method in class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
Check whether Avro type is compatible with Pig type
isComplete(double) - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
isComplex(byte) - Static method in class org.apache.pig.data.DataType
Determine whether the this data type is complex.
isComplex(Object) - Static method in class org.apache.pig.data.DataType
Determine whether the object is complex or atomic.
isConnected(Operator, Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
Check if given two operators are directly connected.
isConnected(Operator, Operator) - Method in class org.apache.pig.tools.pigstats.PigStats.JobGraph
 
isConnectedToPackage() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
isContainer(String) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
isContainer(String) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
isCounterOperation() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isCross() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
isCross - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
isCross() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
isDebugOn() - Method in class org.apache.pig.PigServer
 
isDelimiter(byte[], byte[], int, int, int) - Static method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
isDenseRank() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
isDenseRank() - Method in class org.apache.pig.newplan.logical.relational.LORank
Get if it is a dense RANK BY
isDeterministic() - Method in class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
isDirectory(String, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
isDirectory(String, DataStorage) - Static method in class org.apache.pig.impl.io.FileLocalizer
isDistinct() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.LitePackager
 
isDistinct() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
isDistinct() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
isDistinct() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isDistinct() - Method in class org.apache.pig.data.AccumulativeBag
 
isDistinct() - Method in interface org.apache.pig.data.DataBag
Find out if the bag is distinct.
isDistinct() - Method in class org.apache.pig.data.DefaultDataBag
 
isDistinct() - Method in class org.apache.pig.data.DistinctDataBag
 
isDistinct() - Method in class org.apache.pig.data.InternalCachedBag
 
isDistinct() - Method in class org.apache.pig.data.InternalDistinctBag
 
isDistinct() - Method in class org.apache.pig.data.InternalSortedBag
 
isDistinct() - Method in class org.apache.pig.data.LimitedSortedDataBag
Find out if the bag is distinct.
isDistinct() - Method in class org.apache.pig.data.NonSpillableDataBag
 
isDistinct() - Method in class org.apache.pig.data.ReadOnceBag
 
isDistinct() - Method in class org.apache.pig.data.SingleTupleBag
 
isDistinct() - Method in class org.apache.pig.data.SortedDataBag
 
isDistinct() - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
isDistinct(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubyDataBag
This returns whether the encapsulated DatBag is distinct, per the distinct setting.
isDone() - Method in class org.apache.pig.tools.grunt.GruntParser
 
isDontEstimateParallelism() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
IsDouble - Class in org.apache.pig.piggybank.evaluation
This UDF is used to check whether the String input is a Double.
IsDouble() - Constructor for class org.apache.pig.piggybank.evaluation.IsDouble
 
isEmbedded() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
isEmbedded() - Method in class org.apache.pig.tools.pigstats.mapreduce.SimplePigStats
 
isEmbedded() - Method in class org.apache.pig.tools.pigstats.PigStats
 
isEmbedded() - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
isEmbedded() - Method in class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
isEmpty() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
IsEmpty - Class in org.apache.pig.builtin
Determine whether a bag or map is empty.
IsEmpty() - Constructor for class org.apache.pig.builtin.IsEmpty
 
isEmpty() - Method in class org.apache.pig.impl.util.avro.AvroMapWrapper
 
isEmpty() - Method in class org.apache.pig.impl.util.IdentityHashSet
 
isEmpty() - Method in class org.apache.pig.impl.util.MultiMap
 
isEmpty(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubyDataBag
This method returns whether or not the encapsulated DataBag is empty.
isEndOfAllInput() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
isEndOfAllInputPresent() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter.EndOfAllInputChecker
 
isEndOfAllInputSetInMap() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isEndOfAllInputSetInReduce() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isEndOfInput() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
isEndOfInput() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
isEndOfInput() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
isEndOfInput() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POPoissonSampleSpark
 
isEqual(Operator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternNode
 
isEqual(OperatorPlan) - Method in class org.apache.pig.newplan.BaseOperatorPlan
 
isEqual(OperatorPlan, OperatorPlan) - Static method in class org.apache.pig.newplan.BaseOperatorPlan
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.AddExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.AndExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.BinCondExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.CastExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.ConstantExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.DivideExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.EqualExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.GreaterThanEqualExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.GreaterThanExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.IsNullExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.LessThanEqualExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.LessThanExpression
 
isEqual(OperatorPlan) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionPlan
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.MapLookupExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.ModExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.MultiplyExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.NegativeExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.NotEqualExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.NotExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.OrExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.RegexExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.SubtractExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOCross
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOCube
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LODistinct
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOFilter
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOForEach
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
isEqual(OperatorPlan) - Method in class org.apache.pig.newplan.logical.relational.LogicalPlan
Equality is checked by calling equals on every leaf in the plan.
isEqual(Object) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Two schemas are equal if they are of equal size and their fields schemas considered in order are equal.
isEqual(Object, boolean) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Two schemas are equal if they are of equal size and their fields schemas considered in order are equal.
isEqual(Object) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
Equality is defined as having the same type and either the same schema or both null schema.
isEqual(Object, boolean) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
Equality is defined as having the same type and either the same schema or both null schema.
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOInnerLoad
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOLimit
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LONative
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LORank
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOSplit
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOSplitOutput
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOStream
 
isEqual(Operator) - Method in class org.apache.pig.newplan.logical.relational.LOUnion
 
isEqual(Operator) - Method in class org.apache.pig.newplan.Operator
This is like a shallow equals comparison.
isEqual(OperatorPlan) - Method in interface org.apache.pig.newplan.OperatorPlan
This is like a shallow comparison.
isEqual(OperatorPlan) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
isEqual(Operator) - Method in class org.apache.pig.tools.pigstats.JobStats
 
isEqualUnlessUnknown(LogicalSchema, LogicalSchema) - Static method in class org.apache.pig.newplan.logical.relational.LogicalSchema
 
isEqualUnlessUnknown(LogicalSchema.LogicalFieldSchema, LogicalSchema.LogicalFieldSchema) - Static method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
isFetchable() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
isFetchEnabled(PigContext) - Static method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchOptimizer
Checks whether the fetch is enabled
isFile(String, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
isFile(String, DataStorage) - Static method in class org.apache.pig.impl.io.FileLocalizer
isFilterBloom() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isFilterRemovable() - Method in class org.apache.pig.newplan.FilterExtractor
 
isFinished() - Method in class org.apache.pig.IteratingAccumulatorEvalFunc
 
isFinished() - Method in interface org.apache.pig.TerminatingAccumulator
 
IsFirstReduceOfKey - Class in org.apache.pig.impl.builtin
 
IsFirstReduceOfKey() - Constructor for class org.apache.pig.impl.builtin.IsFirstReduceOfKey
 
IsFirstReduceOfKeyTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.udf
 
IsFirstReduceOfKeyTez() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.IsFirstReduceOfKeyTez
 
isFixedSize() - Method in class org.apache.pig.data.BinSedesTupleFactory
 
isFixedSize() - Method in class org.apache.pig.data.SchemaTupleFactory
 
isFixedSize() - Method in class org.apache.pig.data.TupleFactory
This method is used to inspect whether the Tuples created by this factory will be of a fixed size when they are created.
IsFloat - Class in org.apache.pig.piggybank.evaluation
This UDF is used to check whether the String input is a Float.
IsFloat() - Constructor for class org.apache.pig.piggybank.evaluation.IsFloat
 
isFrontend() - Method in class org.apache.pig.impl.util.UDFContext
Convenience method for UDF code to check where it runs (see PIG-2576)
isGeneratable(Schema) - Static method in class org.apache.pig.data.SchemaTupleFactory
This method inspects a Schema to see whether or not a SchemaTuple implementation can be generated for the types present.
isGeneratedCodeFieldNull(int) - Method in class org.apache.pig.data.SchemaTuple
 
isGloballySorted() - Method in class org.apache.pig.SortInfo
 
isGlobalSort() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isGlobalSort() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
isGlobalSort() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isGroupBy() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isGroupBy() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
isGroupBy() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isHDFSFile(String) - Static method in class org.apache.pig.impl.util.UriUtil
 
isHDFSFileOrLocalOrS3N(String, Configuration) - Static method in class org.apache.pig.impl.util.UriUtil
 
isHeartBeat() - Method in class org.apache.pig.data.TimestampedTuple
 
isInCombiner() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
 
isInCombiner() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Returns a flag indicating if this operator is in a combiner.
isIndexer() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isIndexer() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
isIndexer() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isIndexer() - Method in class org.apache.pig.tools.pigstats.JobStats
 
isInitialized - Variable in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
isInitialized() - Method in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
isInner(int) - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
isInput(byte) - Static method in exception org.apache.pig.PigException
A static method to query if an error source is due to an input or not.
isInputAttached() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
isInstanceCapturingOutput() - Method in class org.apache.pig.scripting.ScriptingOutputCapturer
 
IsInt - Class in org.apache.pig.piggybank.evaluation
This UDF is used to check whether the String input is an Integer.
IsInt() - Constructor for class org.apache.pig.piggybank.evaluation.IsInt
 
isIntermediateReducer() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isJobSuccess(int, JavaSparkContext) - Static method in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
isKeyCompound - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
isKeyCompound() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
isKeyNull(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
isKeyTuple - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
isKeyTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
isLeafNode() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternNode
 
isLeftOuterJoin - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
isLeftOuterJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
isLimit() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
isLimit() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isLimitAfterSort() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isLimitAfterSort() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
isLimitAfterSort() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isLimited() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
isLimited() - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
isLimitOnly() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isLocal() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.LocalExecType
 
isLocal() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRExecType
 
isLocal() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkExecType
 
isLocal() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkLocalExecType
 
isLocal() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezExecType
 
isLocal() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezLocalExecType
 
isLocal() - Method in interface org.apache.pig.ExecType
An ExecType is classified as local if it runs in-process and through the local filesystem.
isLocal(PigContext, Configuration) - Static method in class org.apache.pig.impl.util.Utils
 
isLocal(Configuration) - Static method in class org.apache.pig.impl.util.Utils
 
IsLong - Class in org.apache.pig.piggybank.evaluation
This UDF is used to check whether the String input is a Long.
IsLong() - Constructor for class org.apache.pig.piggybank.evaluation.IsLong
 
isMandatory() - Method in class org.apache.pig.newplan.optimizer.Rule
 
isMapDone() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isMapSideOnly() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
isMultiInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
Returns true if the map has multiple inputs, else false
isMultiInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
isMultiInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
isMultiInputs() - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit
 
isMultiStore() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
isNative() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
isNative() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isNeedEstimateParallelism() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isNegativeInfinity() - Method in class org.apache.pig.builtin.BigDecimalWrapper
 
isNegativeInfinity() - Method in class org.apache.pig.builtin.BigIntegerWrapper
 
isNested() - Method in class org.apache.pig.newplan.logical.relational.LOCross
 
isNonPackageInput(String, TezOperator) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
isNotImplementedAnnotationPresent(Method, Class<?>) - Static method in class org.apache.pig.data.utils.MethodHelper
Given a method and a class, this will return true if the method is declared in the class, and if it is, if the NotImplemented annotation is present.
isNull(int) - Method in class org.apache.pig.data.AbstractTuple
Find out if a given field is null.
isNull(int) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
isNull(int) - Method in class org.apache.pig.data.SchemaTuple
 
isNull - Variable in class org.apache.pig.data.TargetedTuple
 
isNull(int) - Method in interface org.apache.pig.data.Tuple
Find out if a given field is null.
isNull() - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
isNull() - Method in class org.apache.pig.impl.io.PigNullableWritable
 
isNull(int) - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
isNull(int) - Method in class org.apache.pig.pen.util.ExampleTuple
 
isNullableUnion(Schema) - Static method in class org.apache.pig.impl.util.avro.AvroStorageSchemaConversionUtilities
Checks to see if an avro schema is a combination of null and another object.
IsNullExpression - Class in org.apache.pig.newplan.logical.expression
 
IsNullExpression(OperatorPlan, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.IsNullExpression
 
isNumberType(byte) - Static method in class org.apache.pig.data.DataType
Determine if this type is a numeric type.
IsNumeric - Class in org.apache.pig.piggybank.evaluation
This UDF is used to check if a String is numeric.
IsNumeric() - Constructor for class org.apache.pig.piggybank.evaluation.IsNumeric
 
ISODaysBetween - Class in org.apache.pig.piggybank.evaluation.datetime.diff
ISODaysBetween returns the number of days between two ISO8601 datetimes as a Long
ISODaysBetween() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.diff.ISODaysBetween
 
ISOHelper - Class in org.apache.pig.piggybank.evaluation.datetime.truncate
ISOHelper provides helper methods for the other classes in this package.
ISOHelper() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOHelper
 
ISOHoursBetween - Class in org.apache.pig.piggybank.evaluation.datetime.diff
ISOHoursBetween returns the number of hours between two ISO8601 datetimes as a Long
ISOHoursBetween() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.diff.ISOHoursBetween
 
ISOMinutesBetween - Class in org.apache.pig.piggybank.evaluation.datetime.diff
ISOMinutesBetween returns the number of minutes between two ISO8601 datetimes as a Long
ISOMinutesBetween() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.diff.ISOMinutesBetween
 
ISOMonthsBetween - Class in org.apache.pig.piggybank.evaluation.datetime.diff
ISOMonthsBetween returns the number of months between two ISO8601 datetimes as a Long
ISOMonthsBetween() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.diff.ISOMonthsBetween
 
isOnSchema() - Method in class org.apache.pig.newplan.logical.relational.LOUnion
 
isOptimizable(TezOperator) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.UnionOptimizer
 
isOptimizableStoreFunc(TezOperator, List<String>, List<String>) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.UnionOptimizer
 
ISOSecondsBetween - Class in org.apache.pig.piggybank.evaluation.datetime.diff
ISOSecondsBetween returns the number of seconds between two ISO8601 datetimes as a Long
ISOSecondsBetween() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.diff.ISOSecondsBetween
 
ISOToDay - Class in org.apache.pig.piggybank.evaluation.datetime.truncate
ISOToDay truncates an ISO8601 datetime string to the precision of the day field Jodatime: http://joda-time.sourceforge.net/ ISO8601 Date Format: http://en.wikipedia.org/wiki/ISO_8601
ISOToDay() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToDay
 
ISOToHour - Class in org.apache.pig.piggybank.evaluation.datetime.truncate
ISOToHour truncates an ISO8601 datetime string to the precision of the hour field Jodatime: http://joda-time.sourceforge.net/ ISO8601 Date Format: http://en.wikipedia.org/wiki/ISO_8601
ISOToHour() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToHour
 
ISOToMinute - Class in org.apache.pig.piggybank.evaluation.datetime.truncate
ISOToMinute truncates an ISO8601 datetime string to the precision of the minute field Jodatime: http://joda-time.sourceforge.net/ ISO8601 Date Format: http://en.wikipedia.org/wiki/ISO_8601
ISOToMinute() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToMinute
 
ISOToMonth - Class in org.apache.pig.piggybank.evaluation.datetime.truncate
ISOToMonth truncates an ISO8601 datetime string to the precision of the month field Jodatime: http://joda-time.sourceforge.net/ ISO8601 Date Format: http://en.wikipedia.org/wiki/ISO_8601
ISOToMonth() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToMonth
 
ISOToSecond - Class in org.apache.pig.piggybank.evaluation.datetime.truncate
ISOToSecond truncates an ISO8601 datetime string to the precision of the second field Jodatime: http://joda-time.sourceforge.net/ ISO8601 Date Format: http://en.wikipedia.org/wiki/ISO_8601
ISOToSecond() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToSecond
 
ISOToUnix - Class in org.apache.pig.piggybank.evaluation.datetime.convert
ISOToUnix converts ISO8601 datetime strings to Unix Time Longs
ISOToUnix() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.convert.ISOToUnix
 
ISOToWeek - Class in org.apache.pig.piggybank.evaluation.datetime.truncate
ISOToWeek truncates an ISO8601 datetime string to the precision of the day field, for the first day of the week of the datetime.
ISOToWeek() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToWeek
 
ISOToYear - Class in org.apache.pig.piggybank.evaluation.datetime.truncate
 
ISOToYear() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToYear
 
isOverloaded() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
isOverrideIntermediateParallelism() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
ISOYearsBetween - Class in org.apache.pig.piggybank.evaluation.datetime.diff
 
ISOYearsBetween() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.diff.ISOYearsBetween
 
isPinnedOption(Integer) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
isPlanFetchable(PigContext, PhysicalPlan) - Static method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchOptimizer
Visits the plan with FetchablePlanVisitor and checks whether the plan is fetchable.
isPositiveInfinity() - Method in class org.apache.pig.builtin.BigDecimalWrapper
 
isPositiveInfinity() - Method in class org.apache.pig.builtin.BigIntegerWrapper
 
isProjectStar() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
isProjectStar() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
isProjectToEnd - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
isProjectToEnd() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
isRangeOrStarProject() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
isRangeProject() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnInfo
 
isRangeProject() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
isRankCounter() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isRankOperation() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isRecoverySupported() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
isReduceDone() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isRegularJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isRegularJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
isRegularJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isRemoteEnvironment(byte) - Static method in exception org.apache.pig.PigException
A static method to query if an error source is due to the remote environment or not.
isRowNumber() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isRowNumber() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
isRowNumber() - Method in class org.apache.pig.newplan.logical.relational.LORank
Get if it is a simple RANK operation.
isSameMapKeyType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
 
isSample() - Method in class org.apache.pig.newplan.logical.relational.LOFilter
 
isSampleAggregation() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isSampleBasedPartitioner() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isSampler() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isSampler() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
isSampler() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isSampler() - Method in class org.apache.pig.tools.pigstats.JobStats
 
isScalarOutput() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
isSchemaType(Object) - Static method in class org.apache.pig.data.DataType
Determine whether the this object can have a schema.
isSchemaType(byte) - Static method in class org.apache.pig.data.DataType
Determine whether the this data type can have a schema.
isSecondaryKeyTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
isSecondaryProjectStar() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
isSingleLeafPlan() - Method in class org.apache.pig.impl.plan.OperatorPlan
 
isSkewedJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isSkewedJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
isSkewedJoin - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
isSkewedJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
isSkewedJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffleTezLoad
 
isSkewedJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isSkipListener() - Method in class org.apache.pig.newplan.optimizer.Rule
 
isSorted() - Method in class org.apache.pig.data.AccumulativeBag
 
isSorted() - Method in interface org.apache.pig.data.DataBag
Find out if the bag is sorted.
isSorted() - Method in class org.apache.pig.data.DefaultDataBag
 
isSorted() - Method in class org.apache.pig.data.DistinctDataBag
 
isSorted() - Method in class org.apache.pig.data.InternalCachedBag
 
isSorted() - Method in class org.apache.pig.data.InternalDistinctBag
 
isSorted() - Method in class org.apache.pig.data.InternalSortedBag
 
isSorted() - Method in class org.apache.pig.data.LimitedSortedDataBag
Find out if the bag is sorted.
isSorted() - Method in class org.apache.pig.data.NonSpillableDataBag
 
isSorted() - Method in class org.apache.pig.data.ReadOnceBag
 
isSorted() - Method in class org.apache.pig.data.SingleTupleBag
 
isSorted() - Method in class org.apache.pig.data.SortedDataBag
 
isSorted() - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
isSorted(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubyDataBag
This returns whether the encapsulated DatBag is distinct, per the sorted setting.
isSourceNode() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternNode
 
isSpecificSchemaTuple(Object) - Method in class org.apache.pig.data.SchemaTuple
 
isSplitable(JobContext, Path) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat
 
isSplitter() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isSplitter() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
isSplitter() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isStar() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
isStar() - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
isSuccessful() - Method in class org.apache.pig.tools.pigstats.InputStats
 
isSuccessful() - Method in class org.apache.pig.tools.pigstats.JobStats
 
isSuccessful() - Method in class org.apache.pig.tools.pigstats.OutputStats
 
isSuccessful() - Method in class org.apache.pig.tools.pigstats.PigStats
 
isSupportedOpType(BinaryExpression) - Method in class org.apache.pig.newplan.FilterExtractor
 
isSupportedOpType(UnaryExpression) - Method in class org.apache.pig.newplan.FilterExtractor
 
isSupportedOpType(BinaryExpression) - Method in class org.apache.pig.newplan.PartitionFilterExtractor
 
isSupportedOpType(UnaryExpression) - Method in class org.apache.pig.newplan.PartitionFilterExtractor
 
isSupportedOpType(BinaryExpression) - Method in class org.apache.pig.newplan.PredicatePushDownFilterExtractor
 
isSupportedOpType(UnaryExpression) - Method in class org.apache.pig.newplan.PredicatePushDownFilterExtractor
 
isTaskIndexWithRecordIndexAsKey() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
isTempFile(String) - Static method in class org.apache.pig.tools.pigstats.PigStatsUtil
 
isTmpLoad() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
isTmpLoad() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
isTmpStore() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
isTmpStore() - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
isToBeFlattenedArray - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
isTupleByte(byte) - Static method in class org.apache.pig.data.BinInterSedes
 
isTupleWrapper(ResourceSchema.ResourceFieldSchema) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
check whether it is just a wrapped tuple
isTwoLevelAccessRequired() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Deprecated.
twoLevelAccess is no longer needed
isUDFComparatorUsed - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
isUDFConfEmpty() - Method in class org.apache.pig.impl.util.UDFContext
 
isUDPartialRecordSchema(Schema) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
check whether a schema is a space holder (using field name)
isUnion() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
isUnion() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isUnionOfSimpleTypes(Schema) - Static method in class org.apache.pig.impl.util.avro.AvroStorageSchemaConversionUtilities
 
isUsableType(byte) - Static method in class org.apache.pig.data.DataType
Determine if this is a type that can work can be done on.
isUseGraceParallelism() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isUseMRMapSettings() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isUserEnvironment(byte) - Static method in exception org.apache.pig.PigException
A static method to query if an error source is due to the user environment or not.
isUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POGlobalRearrangeSpark
 
isUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
isUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
isUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isUseSecondaryKey() - Method in class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil.SecondaryKeyOptimizerInfo
 
isVendorIBM() - Static method in class org.apache.pig.impl.util.Utils
This method checks whether JVM vendor is IBM
isVerbose - Variable in class org.apache.pig.impl.plan.PlanDumper
 
isVerbose() - Method in class org.apache.pig.impl.plan.PlanDumper
 
isVerbose - Variable in class org.apache.pig.newplan.PlanDumper
 
isVerbose() - Method in class org.apache.pig.newplan.PlanDumper
 
isVertexGroup() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
isViaDefine() - Method in class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
IteratingAccumulatorEvalFunc<T> - Class in org.apache.pig
This class provides a much more intuitive way to write Accumulator UDFs.
For example, you could express IsEmpty as follows:
IteratingAccumulatorEvalFunc() - Constructor for class org.apache.pig.IteratingAccumulatorEvalFunc
 
iterator() - Method in class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
iterator() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl.IllustratorValueIterable
 
iterator() - Method in class org.apache.pig.data.AbstractTuple
 
iterator() - Method in class org.apache.pig.data.AccumulativeBag
 
iterator() - Method in interface org.apache.pig.data.DataBag
Get an iterator to the bag.
iterator() - Method in class org.apache.pig.data.DefaultDataBag
 
iterator() - Method in class org.apache.pig.data.DistinctDataBag
 
iterator() - Method in class org.apache.pig.data.InternalCachedBag
 
iterator() - Method in class org.apache.pig.data.InternalDistinctBag
 
iterator() - Method in class org.apache.pig.data.InternalSortedBag
 
iterator() - Method in class org.apache.pig.data.LimitedSortedDataBag
Get an iterator to the bag.
iterator() - Method in class org.apache.pig.data.NonSpillableDataBag
 
iterator() - Method in class org.apache.pig.data.ReadOnceBag
 
iterator() - Method in class org.apache.pig.data.SingleTupleBag
 
iterator() - Method in class org.apache.pig.data.SortedDataBag
 
iterator() - Method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
iterator() - Method in class org.apache.pig.impl.plan.OperatorPlan
 
iterator() - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
iterator() - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
iterator() - Method in class org.apache.pig.impl.util.IdentityHashSet
 
iterator() - Method in class org.apache.pig.scripting.jruby.RubyDataBag
 
iterator() - Method in class org.apache.pig.tools.pigstats.OutputStats
 
iterator() - Method in class org.apache.pig.tools.pigstats.PigStats.JobGraph
 
its - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
its - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 

J

JAR - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
jarDir(File, String, ZipOutputStream) - Static method in class org.apache.pig.backend.hadoop.accumulo.Utils
 
jarFinderGetJar(Class) - Static method in class org.apache.pig.backend.hadoop.accumulo.Utils
Returns the full path to the Jar containing the class.
JarManager - Class in org.apache.pig.impl.util
 
JarManager() - Constructor for class org.apache.pig.impl.util.JarManager
 
JavaCompilerHelper - Class in org.apache.pig.impl.util
 
JavaCompilerHelper() - Constructor for class org.apache.pig.impl.util.JavaCompilerHelper
 
JavaCompilerHelper.JavaSourceFromString - Class in org.apache.pig.impl.util
This class allows code to be generated directly from a String, instead of having to be on disk.
JavaSourceFromString(String, String) - Constructor for class org.apache.pig.impl.util.JavaCompilerHelper.JavaSourceFromString
 
javaSparkContext - Variable in class org.apache.pig.tools.pigstats.spark.SparkCounterGroup
 
jc - Variable in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
job - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
JOB_APPLICATION_ATTEMPT_ID - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_CACHE_FILES - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_CREDENTIALS_BINARY - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_CREDENTIALS_JSON - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_END_NOTIFICATION_RETRY_INTERVAL - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_HDFS_SERVERS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_ID - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_NAME - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_NAME - Static variable in class org.apache.pig.impl.PigContext
 
JOB_NAME_PREFIX - Static variable in class org.apache.pig.impl.PigContext
 
JOB_PRIORITY - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_PRIORITY - Static variable in class org.apache.pig.impl.PigContext
 
JOB_QUEUE_NAME - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_REDUCE_MARKRESET_BUFFER_PERCENT - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_REDUCES - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_TRACKER - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JOB_TRACKER_HTTP_ADDRESS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
JobControlCompiler - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
This is compiler class that takes an MROperPlan and converts it into a JobControl object with the relevant dependency info maintained.
JobControlCompiler(PigContext, Configuration) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
JobControlCompiler(PigContext, Configuration, Configuration) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
JobControlCompiler.PigBagWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigBigDecimalWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigBigIntegerWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigBooleanWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigCharArrayWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigDateTimeWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigDBAWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigDoubleWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigFloatWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingBagWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingBigDecimalWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingBigIntegerWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingBooleanWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingCharArrayWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingDateTimeWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingDBAWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingDoubleWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingFloatWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingIntWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingLongWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingPartitionWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigGroupingTupleWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigIntWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigLongWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigSecondaryKeyGroupComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigTupleWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
jobControlException - Variable in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
jobControlExceptionStackTrace - Variable in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
JobControlThreadExceptionHandler() - Constructor for class org.apache.pig.backend.hadoop.executionengine.Launcher.JobControlThreadExceptionHandler
 
JobCreationException - Exception in org.apache.pig.backend.hadoop.executionengine
 
JobCreationException() - Constructor for exception org.apache.pig.backend.hadoop.executionengine.JobCreationException
Create a new JobCreationException with null as the error message.
JobCreationException(String) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.JobCreationException
Create a new JobCreationException with the specified cause.
JobCreationException(String, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(String, int) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(String, int, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(String, int, byte) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(String, int, boolean) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(String, int, byte, boolean) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.JobCreationException
Create a new JobCreationException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
JobCreationException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.JobCreationException
Create a new JobCreationException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
jobFailedNotification(String, JobStats) - Method in interface org.apache.pig.tools.pigstats.PigProgressNotificationListener
Invoked when a Hadoop job fails.
jobFinishedNotification(String, JobStats) - Method in interface org.apache.pig.tools.pigstats.PigProgressNotificationListener
Invoked just after a Hadoop job (or Tez DAG) is completed successfully.
JobGraph() - Constructor for class org.apache.pig.tools.pigstats.PigStats.JobGraph
 
JobGraphBuilder - Class in org.apache.pig.backend.hadoop.executionengine.spark
 
JobGraphBuilder(SparkOperPlan, Map<Class<? extends PhysicalOperator>, RDDConverter>, SparkPigStats, JavaSparkContext, JobMetricsListener, String, JobConf, PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.JobGraphBuilder
 
JobGraphPrinter(OperatorPlan) - Constructor for class org.apache.pig.tools.pigstats.PigStats.JobGraphPrinter
 
JobMetricsListener - Class in org.apache.pig.backend.hadoop.executionengine.spark
 
JobMetricsListener() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
jobPlan - Variable in class org.apache.pig.tools.pigstats.PigStats
 
jobsSubmittedNotification(String, int) - Method in interface org.apache.pig.tools.pigstats.PigProgressNotificationListener
Invoked just before submitting a batch of Hadoop jobs (or Tez DAGs).
jobStartedNotification(String, String) - Method in interface org.apache.pig.tools.pigstats.PigProgressNotificationListener
Invoked after a Hadoop job (or Tez DAG) is started.
JobStats - Class in org.apache.pig.tools.pigstats
This class encapsulates the runtime statistics of a MapReduce job.
JobStats(String, PigStats.JobGraph) - Constructor for class org.apache.pig.tools.pigstats.JobStats
 
JobStats.JobState - Enum in org.apache.pig.tools.pigstats
 
join(String, String[]) - Method in class org.apache.pig.impl.plan.PlanDumper
Helper function to print a string array.
join(AbstractCollection<String>, String) - Static method in class org.apache.pig.impl.util.StringUtils
 
join(AbstractCollection<String>, String) - Static method in class org.apache.pig.LoadFunc
Join multiple strings into a string delimited by the given delimiter.
join(String, String[]) - Method in class org.apache.pig.newplan.PlanDumper
Helper function to print a string array.
JoinGroupOptimizerSpark - Class in org.apache.pig.backend.hadoop.executionengine.spark.optimizer
Collapse LocalRearrange,GlobalRearrange,Package to POJoinGroupSpark to reduce unnecessary map operations to optimize join/group.
JoinGroupOptimizerSpark(SparkOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.JoinGroupOptimizerSpark
 
JoinGroupSparkConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
JoinGroupSparkConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.JoinGroupSparkConverter
 
JoinPackager - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
JoinPackager(Packager, POForEach) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.JoinPackager
 
JrubyAccumulatorEvalFunc - Class in org.apache.pig.scripting.jruby
This class provides a bridge between Ruby classes that extend AccumulatorPigUdf and their execution in Pig.
JrubyAccumulatorEvalFunc(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAccumulatorEvalFunc
This constructor is used by JrubyScriptEngine to register a Ruby class as an Accumulator.
JrubyAlgebraicEvalFunc<T> - Class in org.apache.pig.scripting.jruby
This class provides the bridge between Ruby classes that extend the AlgebraicPigUdf "interface" by implementing an initial, intermed, and final method.
JrubyAlgebraicEvalFunc(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc
The constructor takes information on the script and method being invoked and registers it with the superclass (which is necessary for AlgebraicEvalFunc).
JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper<T> - Class in org.apache.pig.scripting.jruby
This is a lightweight wrapper shell that registers information on the method being called, and provides the initializer that the static Algebraic classes (Initial, Intermed, Final) will use to execute.
JrubyAlgebraicEvalFunc.BagJrubyAlgebraicEvalFunc - Class in org.apache.pig.scripting.jruby
Unlike EvalFuncs and Accumulators, the type must be known at compile time (ie it can't return Object), as Pig inspects the type and ensures that it is valid.
JrubyAlgebraicEvalFunc.BagJrubyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.ChararrayJrubyAlgebraicEvalFunc - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.ChararrayJrubyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.DataByteArrayJrubyAlgebraicEvalFunc - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.DataByteArrayJrubyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.DoubleJrubyAlgebraicEvalFunc - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.DoubleJrubyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.Final<T> - Class in org.apache.pig.scripting.jruby
This class invokes the final method on the given Ruby class.
JrubyAlgebraicEvalFunc.FloatJrubyAlgebraicEvalFunc - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.FloatJrubyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.Initial - Class in org.apache.pig.scripting.jruby
This class invokes the initial method on the given Ruby class.
JrubyAlgebraicEvalFunc.IntegerJrubyAlgebraicEvalFunc - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.IntegerJrubyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.Intermed - Class in org.apache.pig.scripting.jruby
This class invokes the intermed method on the given Ruby class.
JrubyAlgebraicEvalFunc.LongJrubyAlgebraicEvalFunc - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.LongJrubyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.MapJrubyAlgebraicEvalFunc - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.MapJrubyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.TupleJrubyAlgebraicEvalFunc - Class in org.apache.pig.scripting.jruby
 
JrubyAlgebraicEvalFunc.TupleJrubyAlgebraicEvalFunc.Final - Class in org.apache.pig.scripting.jruby
 
JrubyEvalFunc - Class in org.apache.pig.scripting.jruby
This class serves at the bridge between Ruby methods that are registered with and extend PigUdf, and their execution in Pig.
JrubyEvalFunc(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyEvalFunc
The constructor for this class registers the filename of the Ruby script and the name of the method we care about.
JrubyScriptEngine - Class in org.apache.pig.scripting.jruby
Implementation of the script engine for Jruby, which facilitates the registration of scripts as UDFs, and also provides information (via the nested class RubyFunctions) on the registered functions.
JrubyScriptEngine() - Constructor for class org.apache.pig.scripting.jruby.JrubyScriptEngine
 
jsCall(String, Object[]) - Method in class org.apache.pig.scripting.js.JsScriptEngine
call a javascript function
jsEval(String, String) - Method in class org.apache.pig.scripting.js.JsScriptEngine
evaluate a javascript String
jsEval(String, Reader) - Method in class org.apache.pig.scripting.js.JsScriptEngine
evaluate javascript from a reader
JsFunction - Class in org.apache.pig.scripting.js
 
JsFunction(String) - Constructor for class org.apache.pig.scripting.js.JsFunction
 
jsNewArray(long) - Method in class org.apache.pig.scripting.js.JsScriptEngine
creates a new javascript array
jsNewObject() - Method in class org.apache.pig.scripting.js.JsScriptEngine
creates a new JavaScript object
JsonLoader - Class in org.apache.pig.builtin
A loader for data stored using JsonStorage.
JsonLoader() - Constructor for class org.apache.pig.builtin.JsonLoader
 
JsonLoader(String) - Constructor for class org.apache.pig.builtin.JsonLoader
 
JsonMetadata - Class in org.apache.pig.builtin
Reads and Writes metadata using JSON in metafiles next to the data.
JsonMetadata() - Constructor for class org.apache.pig.builtin.JsonMetadata
 
JsonMetadata(String, String, String) - Constructor for class org.apache.pig.builtin.JsonMetadata
 
JsonMetadata - Class in org.apache.pig.piggybank.storage
Deprecated.
JsonMetadata() - Constructor for class org.apache.pig.piggybank.storage.JsonMetadata
Deprecated.
 
JsonStorage - Class in org.apache.pig.builtin
A JSON Pig store function.
JsonStorage() - Constructor for class org.apache.pig.builtin.JsonStorage
 
JSPig - Class in org.apache.pig.scripting.js
Pig entry point from javascript
jsPut(String, Object) - Method in class org.apache.pig.scripting.js.JsScriptEngine
put a value in the current scope
JsScriptEngine - Class in org.apache.pig.scripting.js
ScriptEngine implementation for JavaScript
JsScriptEngine() - Constructor for class org.apache.pig.scripting.js.JsScriptEngine
 
JVMReuseImpl - Class in org.apache.pig
 
JVMReuseImpl() - Constructor for class org.apache.pig.JVMReuseImpl
 
JVMReuseManager - Class in org.apache.pig
This class is used to manage JVM Reuse in case of execution engines like Tez and Spark.
JythonFunction - Class in org.apache.pig.scripting.jython
Python implementation of a Pig UDF Performs mappings between Python & Pig data structures
JythonFunction(String, String) - Constructor for class org.apache.pig.scripting.jython.JythonFunction
 
JythonScriptEngine - Class in org.apache.pig.scripting.jython
Implementation of the script engine for Jython
JythonScriptEngine() - Constructor for class org.apache.pig.scripting.jython.JythonScriptEngine
 
JythonUtils - Class in org.apache.pig.scripting.jython
 
JythonUtils() - Constructor for class org.apache.pig.scripting.jython.JythonUtils
 

K

key - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
key - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
key() - Method in enum org.apache.pig.data.SchemaTupleClassGenerator.GenContext
 
keyInfo - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
keySchemas - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
KEYSET - Class in org.apache.pig.builtin
This UDF takes a Map and returns a Bag containing the keyset.
KEYSET() - Constructor for class org.apache.pig.builtin.KEYSET
 
keySet() - Method in class org.apache.pig.impl.util.avro.AvroMapWrapper
 
keySet() - Method in class org.apache.pig.impl.util.MultiMap
Get a set of all the keys in this map.
KeyState() - Constructor for class org.apache.pig.newplan.FilterExtractor.KeyState
 
keyType - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
 
keyType - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
keyType - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
keyType - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
keyType - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
keyType - Variable in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
KeyTypeDiscoveryVisitor - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
A visitor to figure out the type of the key for the map plan this is needed when the key is null to create an appropriate NullableXXXWritable object
KeyTypeDiscoveryVisitor(MROperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.KeyTypeDiscoveryVisitor
 
keyTypes - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
keyWritable - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
keyWritable - Variable in class org.apache.pig.data.ReadOnceBag
 
kill() - Method in interface org.apache.pig.backend.executionengine.ExecJob
Kills current job.
kill() - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
This method is called when user requests to kill all jobs associated with the execution engine
kill() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
kill() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
kill() - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
kill() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceLauncher
 
kill() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkLauncher
 
kill() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezLauncher
 
killJob(String) - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
This method is called when a user requests to kill a job associated with the given job id.
killJob(String) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
killJob(String, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
killJob(String, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceLauncher
 
killJob(String, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkLauncher
 
killJob() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
killJob(String, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezLauncher
 
KryoSerializer - Class in org.apache.pig.backend.hadoop.executionengine.spark
Pulled class from Hive on Spark
KryoSerializer() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.KryoSerializer
 

L

LA(int) - Method in class org.apache.pig.parser.QueryParserFileStream
 
LA(int, int, int, char[]) - Static method in class org.apache.pig.parser.QueryParserStreamUtil
Refer to ANTLRStringStream class for definitions of n, p, and data.
LA(int) - Method in class org.apache.pig.parser.QueryParserStringStream
 
LAST_INDEX_OF - Class in org.apache.pig.builtin
string.INSTR implements eval function to search for the last occurrence of a string Returns null on error Example: A = load 'mydata' as (name); B = foreach A generate LASTINDEXOF(name, ",");
LAST_INDEX_OF() - Constructor for class org.apache.pig.builtin.LAST_INDEX_OF
 
LASTINDEXOF - Class in org.apache.pig.piggybank.evaluation.string
Deprecated.
LASTINDEXOF() - Constructor for class org.apache.pig.piggybank.evaluation.string.LASTINDEXOF
Deprecated.
 
launchCompletedNotification(String, int) - Method in interface org.apache.pig.tools.pigstats.PigProgressNotificationListener
Invoked just after all Hadoop jobs (Tez DAGs) spawned by the script are completed.
launcher - Variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
Launcher - Class in org.apache.pig.backend.hadoop.executionengine
Provides core processing implementation for the backend of Pig if ExecutionEngine chosen decides to delegate it's work to this class.
Launcher() - Constructor for class org.apache.pig.backend.hadoop.executionengine.Launcher
 
Launcher.HangingJobKiller - Class in org.apache.pig.backend.hadoop.executionengine
 
Launcher.JobControlThreadExceptionHandler - Class in org.apache.pig.backend.hadoop.executionengine
An exception handler class to handle exceptions thrown by the job controller thread Its a local class.
launchPig(LogicalPlan, String, PigContext) - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
This method is responsible for the actual execution of a LogicalPlan.
launchPig(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchLauncher
Runs the fetch task by executing chain of calls on the PhysicalPlan from the leaf up to the LoadFunc
launchPig(LogicalPlan, String, PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
launchPig(PhysicalPlan, String, PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
Method to launch pig for hadoop either for a cluster's job tracker or for a local job runner.
launchPig(PhysicalPlan, String, PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceLauncher
 
launchPig(PhysicalPlan, String, PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkLauncher
 
launchPig(PhysicalPlan, String, PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezLauncher
 
launchPig(PhysicalPlan, Map<LOLoad, DataBag>, LineageTracer, IllustratorAttacher, ExampleGenerator, PigContext) - Method in class org.apache.pig.pen.LocalMapReduceSimulator
 
launchPlan(LogicalPlan, String) - Method in class org.apache.pig.PigServer
A common method for launching the jobs according to the logical plan
launchStartedNotification(String, int) - Method in interface org.apache.pig.tools.pigstats.PigProgressNotificationListener
Invoked just before launching Hadoop jobs (or tez DAGs) spawned by the script.
lazyReset(PigContext) - Static method in class org.apache.pig.data.SchemaTupleFrontend
This is a method which caches a PigContext object that has had relevant key values set by SchemaTupleBackend.
LCFIRST - Class in org.apache.pig.builtin
lower-case the first character of a string
LCFIRST() - Constructor for class org.apache.pig.builtin.LCFIRST
 
LcFirst - Class in org.apache.pig.piggybank.evaluation.string
Deprecated.
LcFirst() - Constructor for class org.apache.pig.piggybank.evaluation.string.LcFirst
Deprecated.
 
leaf - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter.PigReduceCounter
 
leafOps - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
leafOps - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
leafOps - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
leaves - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter.PigReduceCounter
 
LENGTH - Class in org.apache.pig.piggybank.evaluation.string
string.LENGTH implements eval function to find length of a string Example: register piggybank.jar; A = load 'mydata' as (name); B = foreach A generate string.LENGTH(name); dump B;
LENGTH() - Constructor for class org.apache.pig.piggybank.evaluation.string.LENGTH
 
length() - Method in class org.apache.pig.piggybank.storage.avro.AvroStorageInputStream
 
LENGTH_KEY - Static variable in interface org.apache.pig.backend.datastorage.ElementDescriptor
Available from getStatistics as a Long.
LessThanEqualExpression - Class in org.apache.pig.newplan.logical.expression
 
LessThanEqualExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.LessThanEqualExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
LessThanExpr - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
LessThanExpr(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LessThanExpr
 
LessThanExpr(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LessThanExpr
 
LessThanExpression - Class in org.apache.pig.newplan.logical.expression
 
LessThanExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.LessThanExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
lhs - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
limit - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat.RecordReaderFactory
 
limit_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
LimitAdjuster - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
LimitAdjuster(MROperPlan, PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.LimitAdjuster
 
LimitConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
LimitConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.LimitConverter
 
LimitedSortedDataBag - Class in org.apache.pig.data
An ordered collection of Tuples (possibly) with multiples.
LimitedSortedDataBag(Comparator<Tuple>, long) - Constructor for class org.apache.pig.data.LimitedSortedDataBag
 
LimitOptimizer - Class in org.apache.pig.newplan.logical.rules
 
LimitOptimizer(String) - Constructor for class org.apache.pig.newplan.logical.rules.LimitOptimizer
 
LimitOptimizer.OptimizeLimitTransformer - Class in org.apache.pig.newplan.logical.rules
 
line() - Method in class org.apache.pig.parser.SourceLocation
 
LineageFindRelVisitor - Class in org.apache.pig.newplan.logical.visitor
Create mapping between uid and Load FuncSpec when the LogicalExpression associated with it is known to hold an unmodified element of data returned by the load function.
LineageFindRelVisitor(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
lineageTracer - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
LineageTracer - Class in org.apache.pig.impl.util
 
LineageTracer() - Constructor for class org.apache.pig.impl.util.LineageTracer
 
LineageTracer - Class in org.apache.pig.pen.util
 
LineageTracer() - Constructor for class org.apache.pig.pen.util.LineageTracer
 
LineageTrimmingVisitor - Class in org.apache.pig.pen
 
LineageTrimmingVisitor(LogicalPlan, Map<LOLoad, DataBag>, ExampleGenerator, Map<Operator, PhysicalOperator>, PhysicalPlan, PigContext) - Constructor for class org.apache.pig.pen.LineageTrimmingVisitor
 
LINEFEED - Static variable in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
lineNum - Variable in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
LINERECORDREADER_MAXLENGTH - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
LinkedMultiMap<K,V> - Class in org.apache.pig.impl.util
 
LinkedMultiMap() - Constructor for class org.apache.pig.impl.util.LinkedMultiMap
 
LinkedMultiMap(int) - Constructor for class org.apache.pig.impl.util.LinkedMultiMap
 
listeners - Variable in class org.apache.pig.newplan.optimizer.PlanOptimizer
 
listeners - Variable in class org.apache.pig.tools.pigstats.ScriptState
 
listPaths(String) - Method in class org.apache.pig.PigServer
List the contents of a directory.
listStatus(JobContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigFileInputFormat
 
listStatus(JobContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSequenceFileInputFormat
 
listStatus(JobContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTextInputFormat
 
listStatus(JobContext) - Method in class org.apache.pig.piggybank.storage.AllLoader.AllLoaderInputFormat
 
listStatus(JobContext) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroInputFormat
 
listStatus(JobContext) - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCInputFormat
 
listStatus(JobContext, Class<? extends LoadFunc>, String) - Method in class org.apache.pig.piggybank.storage.partition.PathPartitionHelper
This method is called by the FileInputFormat to find the input paths for which splits should be calculated.
If applyDateRanges == true: Then the HiveRCDateSplitter is used to apply filtering on the input files.
Else the default FileInputFormat listStatus method is used.
listToString(List<String>) - Static method in class org.apache.pig.piggybank.storage.hiverc.HiveRCSchemaUtil
Trims items in the list.
LitePackager - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
This package operator is a specialization of POPackage operator used for the specific case of the order by query.
LitePackager() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.LitePackager
 
load(LoadFunc, PigContext) - Method in class org.apache.pig.impl.io.PigFile
 
load(Ruby, boolean) - Method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
This method is called from JRuby to register any classes in the library.
load(String, InputStream) - Method in class org.apache.pig.scripting.js.JsScriptEngine
 
load(InputStream, String, PigContext) - Method in class org.apache.pig.scripting.jython.JythonScriptEngine
execs the script text using the interpreter.
loadCandidateKeywords(InputStream, Set<String>) - Static method in class org.apache.pig.tools.grunt.PigCompletor
 
LoadCaster - Interface in org.apache.pig
An interface that provides cast implementations for load functions.
LoadConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
Converter that loads data via POLoad and converts it to RRD<Tuple>.
LoadConverter(PigContext, PhysicalPlan, SparkContext, JobConf, SparkEngineConf) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.LoadConverter
 
loadDefaultProperties(Properties) - Static method in class org.apache.pig.impl.util.PropertiesUtil
Loads the default properties from pig-default.properties and pig.properties.
loadDefaultProperties() - Static method in class org.apache.pig.impl.util.PropertiesUtil
Loads default properties.
loadDependentJars(Configuration) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
Ensure that Accumulo's dependent jars are added to the Configuration to alleviate the need for clients to REGISTER dependency jars.
loader - Variable in class org.apache.pig.impl.builtin.SampleLoader
 
LoaderInfo() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.LoaderInfo
 
LoaderProcessor - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
 
LoaderProcessor(TezOperPlan, PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.LoaderProcessor
 
loadFunc - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat.RecordReaderFactory
 
LoadFunc - Class in org.apache.pig
A LoadFunc loads data into Pig.
LoadFunc() - Constructor for class org.apache.pig.LoadFunc
 
loadFunc() - Method in class org.apache.pig.LoadFuncWrapper
 
LoadFuncHelper - Class in org.apache.pig.piggybank.storage.allloader
Contains the logic for finding a LoadFunc based on the definition of: file.extension.loaders file.format.loaders
LoadFuncHelper(Configuration) - Constructor for class org.apache.pig.piggybank.storage.allloader.LoadFuncHelper
 
LoadFuncMetadataWrapper - Class in org.apache.pig
Convenience class to extend when decorating a class that extends LoadFunc and implements LoadMetadata.
LoadFuncMetadataWrapper() - Constructor for class org.apache.pig.LoadFuncMetadataWrapper
 
LoadFuncWrapper - Class in org.apache.pig
Convenience class to extend when decorating a LoadFunc.
LoadFuncWrapper() - Constructor for class org.apache.pig.LoadFuncWrapper
 
LoadMetadata - Interface in org.apache.pig
This interface defines how to retrieve metadata related to data to be loaded.
loadParamVal(List<String>, List<String>) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
 
loadPartitionFileFromLocalCache(String, Integer[], byte, Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
Loads the key distribution sampler file
LoadPredicatePushdown - Interface in org.apache.pig
This interface defines how a loader can support predicate pushdown.
loadPropertiesFromFile(Properties, String) - Static method in class org.apache.pig.impl.util.PropertiesUtil
Loads the properties from a given file.
LoadPushDown - Interface in org.apache.pig
This interface defines how to communicate to Pig what functionality can be pushed into the loader.
LoadPushDown.OperatorSet - Enum in org.apache.pig
Set of possible operations that Pig can push down to a loader.
LoadPushDown.RequiredField - Class in org.apache.pig
Describes a field that is required to execute a scripts.
LoadPushDown.RequiredFieldList - Class in org.apache.pig
List of fields that Pig knows to be required to executed a script.
LoadPushDown.RequiredFieldResponse - Class in org.apache.pig
Indicates whether the loader will return the requested fields or all fields.
LoadStoreCaster - Interface in org.apache.pig
This is just a union interface of LoadCaster and StoreCaster, made available for simplicity.
LoadTypeCastInserter - Class in org.apache.pig.newplan.logical.rules
 
LoadTypeCastInserter(String) - Constructor for class org.apache.pig.newplan.logical.rules.LoadTypeCastInserter
 
LOCAL - Static variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
LOCAL - Static variable in interface org.apache.pig.ExecType
 
LOCAL_CODE_DIR - Static variable in class org.apache.pig.PigConstants
This key is used when a job is run in local mode to pass the location of the generated code from the front-end to the "back-end" (which, in this case, is in the same JVM).
LOCAL_PREFIX - Static variable in class org.apache.pig.impl.io.FileLocalizer
 
LocalExecType - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
LocalExecType is the ExecType for local mode in Hadoop Mapreduce.
LocalExecType() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.LocalExecType
 
LocalMapReduceSimulator - Class in org.apache.pig.pen
Main class that launches pig for Map Reduce
LocalMapReduceSimulator() - Constructor for class org.apache.pig.pen.LocalMapReduceSimulator
 
LocalRearrangeConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
LocalRearrangeConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.LocalRearrangeConverter
 
location - Variable in class org.apache.pig.newplan.Operator
 
LOCogroup - Class in org.apache.pig.newplan.logical.relational
 
LOCogroup(LogicalPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOCogroup
Constructor for use in defining rule patterns
LOCogroup(OperatorPlan, MultiMap<Integer, LogicalExpressionPlan>, boolean[]) - Constructor for class org.apache.pig.newplan.logical.relational.LOCogroup
 
LOCogroup(OperatorPlan, MultiMap<Integer, LogicalExpressionPlan>, LOCogroup.GROUPTYPE, boolean[]) - Constructor for class org.apache.pig.newplan.logical.relational.LOCogroup
 
LOCogroup.GROUPTYPE - Enum in org.apache.pig.newplan.logical.relational
Enum for the type of group
LOCross - Class in org.apache.pig.newplan.logical.relational
 
LOCross(LogicalPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOCross
 
LOCube - Class in org.apache.pig.newplan.logical.relational
CUBE operator implementation for data cube computation.
LOCube(LogicalPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOCube
 
LOCube(OperatorPlan, MultiMap<Integer, LogicalExpressionPlan>) - Constructor for class org.apache.pig.newplan.logical.relational.LOCube
 
LODistinct - Class in org.apache.pig.newplan.logical.relational
 
LODistinct(LogicalPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LODistinct
 
LOFilter - Class in org.apache.pig.newplan.logical.relational
 
LOFilter(LogicalPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOFilter
 
LOFilter(LogicalPlan, LogicalExpressionPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOFilter
 
LOFilter(LogicalPlan, boolean) - Constructor for class org.apache.pig.newplan.logical.relational.LOFilter
 
LOFilter(LogicalPlan, LogicalExpressionPlan, boolean) - Constructor for class org.apache.pig.newplan.logical.relational.LOFilter
 
LOForEach - Class in org.apache.pig.newplan.logical.relational
 
LOForEach(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOForEach
 
log - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
 
log - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
log - Variable in class org.apache.pig.builtin.AvroStorage
 
LOG - Class in org.apache.pig.builtin
LOG implements a binding to the Java function Math.log(double).
LOG() - Constructor for class org.apache.pig.builtin.LOG
 
log - Static variable in class org.apache.pig.builtin.OrcStorage
 
log - Variable in class org.apache.pig.EvalFunc
Logging object.
log - Static variable in class org.apache.pig.impl.plan.OperatorPlan
 
log - Static variable in class org.apache.pig.newplan.BaseOperatorPlan
 
LOG - Variable in class org.apache.pig.newplan.FilterExtractor
 
log - Static variable in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
log - Static variable in class org.apache.pig.newplan.optimizer.Rule
 
LOG - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use LOG
LOG() - Constructor for class org.apache.pig.piggybank.evaluation.math.LOG
Deprecated.
 
LOG - Static variable in class org.apache.pig.piggybank.storage.CSVLoader
 
LOG - Static variable in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
LOG - Static variable in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
log - Variable in class org.apache.pig.PigServer
 
LOG10 - Class in org.apache.pig.builtin
LOG10 implements a binding to the Java function Math.log10(double).
LOG10() - Constructor for class org.apache.pig.builtin.LOG10
 
LOG10 - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use LOG10
LOG10() - Constructor for class org.apache.pig.piggybank.evaluation.math.LOG10
Deprecated.
 
LOG1P - Class in org.apache.pig.piggybank.evaluation.math
math.LOG1P implements a binding to the Java function Math.log1p(double).
LOG1P() - Constructor for class org.apache.pig.piggybank.evaluation.math.LOG1P
 
LOG_DIR - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
logAggregate(Map<Enum, Long>, CompilationMessageCollector.MessageType, Log) - Static method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
logAllMessages(CompilationMessageCollector, Log) - Static method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
logAllMessages(Log) - Method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
LOGenerate - Class in org.apache.pig.newplan.logical.relational
 
LOGenerate(OperatorPlan, List<LogicalExpressionPlan>, boolean[]) - Constructor for class org.apache.pig.newplan.logical.relational.LOGenerate
 
LOGenerate(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOGenerate
 
logEvent(PigATSClient.ATSEvent) - Method in class org.apache.pig.backend.hadoop.PigATSClient
 
LogFormatLoader - Class in org.apache.pig.piggybank.storage.apachelog
This is a pig loader that can load Apache HTTPD access logs written in (almost) any Apache HTTPD LogFormat.
Basic usage:
Simply feed the loader your (custom) logformat specification and it will tell you which fields can be extracted from this logformat.
For example:
LogFormatLoader(String...) - Constructor for class org.apache.pig.piggybank.storage.apachelog.LogFormatLoader
 
LogicalExpression - Class in org.apache.pig.newplan.logical.expression
Logical representation of expression operators.
LogicalExpression(String, OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.expression.LogicalExpression
 
LogicalExpressionPlan - Class in org.apache.pig.newplan.logical.expression
A plan containing LogicalExpressionOperators.
LogicalExpressionPlan() - Constructor for class org.apache.pig.newplan.logical.expression.LogicalExpressionPlan
 
LogicalExpressionVisitor - Class in org.apache.pig.newplan.logical.expression
A visitor for expression plans.
LogicalExpressionVisitor(OperatorPlan, PlanWalker) - Constructor for class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
LogicalFieldSchema(String, LogicalSchema, byte) - Constructor for class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
LogicalFieldSchema(LogicalSchema.LogicalFieldSchema) - Constructor for class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
LogicalFieldSchema(String, LogicalSchema, byte, long) - Constructor for class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
LogicalPlan - Class in org.apache.pig.newplan.logical.relational
LogicalPlan is the logical view of relational operations Pig will execute for a given script.
LogicalPlan(LogicalPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LogicalPlan
 
LogicalPlan() - Constructor for class org.apache.pig.newplan.logical.relational.LogicalPlan
 
LogicalPlanBuilder - Class in org.apache.pig.parser
 
LogicalPlanData - Class in org.apache.pig.newplan.logical.relational
This class provides information regarding the LogicalPlan.
LogicalPlanData(LogicalPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LogicalPlanData
 
LogicalPlanOptimizer - Class in org.apache.pig.newplan.logical.optimizer
 
LogicalPlanOptimizer(OperatorPlan, int, Set<String>) - Constructor for class org.apache.pig.newplan.logical.optimizer.LogicalPlanOptimizer
 
LogicalPlanOptimizer(OperatorPlan, int, Set<String>, PigContext) - Constructor for class org.apache.pig.newplan.logical.optimizer.LogicalPlanOptimizer
Create a new LogicalPlanOptimizer.
LogicalPlanPrinter - Class in org.apache.pig.newplan.logical.optimizer
A visitor mechanism printing out the logical plan.
LogicalPlanPrinter(OperatorPlan, PrintStream) - Constructor for class org.apache.pig.newplan.logical.optimizer.LogicalPlanPrinter
 
LogicalRelationalNodesVisitor - Class in org.apache.pig.newplan.logical.relational
A visitor for logical plans.
LogicalRelationalNodesVisitor(OperatorPlan, PlanWalker) - Constructor for class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
LogicalRelationalNodeValidator - Interface in org.apache.pig.newplan.logical.rules
Implementors of this interface would define validations based on logical operators within a Pig script.
LogicalRelationalOperator - Class in org.apache.pig.newplan.logical.relational
Logical representation of relational operators.
LogicalRelationalOperator(String, OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
LogicalRelationalOperator(String, OperatorPlan, int) - Constructor for class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
LogicalSchema - Class in org.apache.pig.newplan.logical.relational
Schema, from a logical perspective.
LogicalSchema() - Constructor for class org.apache.pig.newplan.logical.relational.LogicalSchema
 
LogicalSchema.LogicalFieldSchema - Class in org.apache.pig.newplan.logical.relational
 
LogicalSchema.MergeMode - Enum in org.apache.pig.newplan.logical.relational
 
logicalToPhysicalKeys - Variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
LogicalToPhysicalTranslatorException - Exception in org.apache.pig.backend.hadoop.executionengine.physicalLayer
 
LogicalToPhysicalTranslatorException() - Constructor for exception org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogicalToPhysicalTranslatorException
Create a new LogicalToPhysicalTranslatorException with null as the error message.
LogicalToPhysicalTranslatorException(String) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogicalToPhysicalTranslatorException
Create a new LogicalToPhysicalTranslatorException with the specified message and cause.
LogicalToPhysicalTranslatorException(Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogicalToPhysicalTranslatorException
Create a new LogicalToPhysicalTranslatorException with the specified cause.
LogicalToPhysicalTranslatorException(String, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogicalToPhysicalTranslatorException
Create a new LogicalToPhysicalTranslatorException with the specified message and cause.
LogicalToPhysicalTranslatorException(String, int) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogicalToPhysicalTranslatorException
Create a new LogicalToPhysicalTranslatorException with the specified message and cause.
LogicalToPhysicalTranslatorException(String, int, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogicalToPhysicalTranslatorException
Create a new LogicalToPhysicalTranslatorException with the specified message and cause.
LogicalToPhysicalTranslatorException(String, int, byte) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogicalToPhysicalTranslatorException
Create a new LogicalToPhysicalTranslatorException with the specified message and cause.
LogicalToPhysicalTranslatorException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogicalToPhysicalTranslatorException
Create a new LogicalToPhysicalTranslatorException with the specified message and cause.
LogicalToPhysicalTranslatorException(String, int, boolean) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogicalToPhysicalTranslatorException
Create a new LogicalToPhysicalTranslatorException with the specified message and cause.
LogicalToPhysicalTranslatorException(String, int, byte, boolean) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogicalToPhysicalTranslatorException
Create a new LogicalToPhysicalTranslatorException with the specified message and cause.
LogicalToPhysicalTranslatorException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogicalToPhysicalTranslatorException
Create a new LogicalToPhysicalTranslatorException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
LogicalToPhysicalTranslatorException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogicalToPhysicalTranslatorException
Create a new LogicalToPhysicalTranslatorException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
logMessages(CompilationMessageCollector, CompilationMessageCollector.MessageType, boolean, Log) - Static method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
logMessages(CompilationMessageCollector.MessageType, boolean, Log) - Method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
logToPhyMap - Variable in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
logToPhyMap - Variable in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
LogToPhyTranslationVisitor - Class in org.apache.pig.newplan.logical.relational
 
LogToPhyTranslationVisitor(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
LogUtils - Class in org.apache.pig.impl.util
 
LogUtils() - Constructor for class org.apache.pig.impl.util.LogUtils
 
LOInnerLoad - Class in org.apache.pig.newplan.logical.relational
Operator to map the data into the inner plan of LOForEach It can only be used in the inner plan of LOForEach
LOInnerLoad(OperatorPlan, LOForEach, int) - Constructor for class org.apache.pig.newplan.logical.relational.LOInnerLoad
 
LOInnerLoad(OperatorPlan, LOForEach, String) - Constructor for class org.apache.pig.newplan.logical.relational.LOInnerLoad
 
LOInnerLoad(LogicalPlan, LOForEach, ProjectExpression) - Constructor for class org.apache.pig.newplan.logical.relational.LOInnerLoad
 
LOJoin - Class in org.apache.pig.newplan.logical.relational
 
LOJoin(LogicalPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOJoin
 
LOJoin(LogicalPlan, MultiMap<Integer, LogicalExpressionPlan>, LOJoin.JOINTYPE, boolean[]) - Constructor for class org.apache.pig.newplan.logical.relational.LOJoin
 
LOJoin.JOINTYPE - Enum in org.apache.pig.newplan.logical.relational
Enum for the type of join
LOLimit - Class in org.apache.pig.newplan.logical.relational
 
LOLimit(LogicalPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOLimit
 
LOLimit(LogicalPlan, long) - Constructor for class org.apache.pig.newplan.logical.relational.LOLimit
 
LOLimit(LogicalPlan, LogicalExpressionPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOLimit
 
LOLoad - Class in org.apache.pig.newplan.logical.relational
 
LOLoad(LogicalSchema, LogicalPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOLoad
used for pattern matching
LOLoad(FileSpec, LogicalSchema, LogicalPlan, Configuration, LoadFunc, String) - Constructor for class org.apache.pig.newplan.logical.relational.LOLoad
Used from the LogicalPlanBuilder
LOLoad.CastState - Enum in org.apache.pig.newplan.logical.relational
 
LONative - Class in org.apache.pig.newplan.logical.relational
 
LONative(OperatorPlan, String, String[]) - Constructor for class org.apache.pig.newplan.logical.relational.LONative
 
LONG - Static variable in class org.apache.pig.data.BinInterSedes
 
LONG - Static variable in class org.apache.pig.data.DataType
 
LONG_0 - Static variable in class org.apache.pig.data.BinInterSedes
 
LONG_1 - Static variable in class org.apache.pig.data.BinInterSedes
 
LONG_INBYTE - Static variable in class org.apache.pig.data.BinInterSedes
 
LONG_ININT - Static variable in class org.apache.pig.data.BinInterSedes
 
LONG_INSHORT - Static variable in class org.apache.pig.data.BinInterSedes
 
LongAbs - Class in org.apache.pig.builtin
 
LongAbs() - Constructor for class org.apache.pig.builtin.LongAbs
 
LongAbs - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
LongAbs() - Constructor for class org.apache.pig.piggybank.evaluation.math.LongAbs
Deprecated.
 
LongAvg - Class in org.apache.pig.builtin
This method should never be used directly, use AVG.
LongAvg() - Constructor for class org.apache.pig.builtin.LongAvg
 
LongAvg.Final - Class in org.apache.pig.builtin
 
LongAvg.Initial - Class in org.apache.pig.builtin
 
LongAvg.Intermediate - Class in org.apache.pig.builtin
 
LongGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.LongGroovyAlgebraicEvalFunc
 
LongJrubyAlgebraicEvalFunc(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.LongJrubyAlgebraicEvalFunc
 
LongMax - Class in org.apache.pig.builtin
This method should never be used directly, use MAX.
LongMax() - Constructor for class org.apache.pig.builtin.LongMax
 
LongMax - Class in org.apache.pig.piggybank.evaluation.math
math.max implements a binding to the Java function Math.max(long,long) for computing the the max value of the arguments.
LongMax() - Constructor for class org.apache.pig.piggybank.evaluation.math.LongMax
 
LongMax.Final - Class in org.apache.pig.builtin
 
LongMax.Intermediate - Class in org.apache.pig.builtin
 
LongMin - Class in org.apache.pig.builtin
This method should never be used directly, use MIN.
LongMin() - Constructor for class org.apache.pig.builtin.LongMin
 
LongMin - Class in org.apache.pig.piggybank.evaluation.math
math.min implements a binding to the Java function Math.min(long,long) for computing the the min value of the arguments.
LongMin() - Constructor for class org.apache.pig.piggybank.evaluation.math.LongMin
 
LongMin.Final - Class in org.apache.pig.builtin
 
LongMin.Intermediate - Class in org.apache.pig.builtin
 
LongSchema - Static variable in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
 
LongSparkCounter() - Constructor for class org.apache.pig.tools.pigstats.spark.SparkCounter.LongSparkCounter
 
LongSparkCounter(String, String, String, Long, JavaSparkContext) - Constructor for class org.apache.pig.tools.pigstats.spark.SparkCounter.LongSparkCounter
 
LongSparkCounterGroup(String, String, JavaSparkContext) - Constructor for class org.apache.pig.tools.pigstats.spark.SparkCounterGroup.LongSparkCounterGroup
 
LongSum - Class in org.apache.pig.builtin
This method should never be used directly, use SUM.
LongSum() - Constructor for class org.apache.pig.builtin.LongSum
 
LongSum.Final - Class in org.apache.pig.builtin
 
LongSum.Intermediate - Class in org.apache.pig.builtin
 
LookupInFiles - Class in org.apache.pig.piggybank.evaluation.string
Syntax: int lookupInFiles(String expression,...
LookupInFiles() - Constructor for class org.apache.pig.piggybank.evaluation.string.LookupInFiles
 
LORank - Class in org.apache.pig.newplan.logical.relational
RANK operator implementation.
LORank(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LORank
 
LORank(OperatorPlan, List<LogicalExpressionPlan>, List<Boolean>) - Constructor for class org.apache.pig.newplan.logical.relational.LORank
 
LoRearrangeDiscoverer(PhysicalPlan, TezOperator, TezOperator, POPackage) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOPackageAnnotator.LoRearrangeDiscoverer
 
LOSort - Class in org.apache.pig.newplan.logical.relational
 
LOSort(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOSort
 
LOSort(OperatorPlan, List<LogicalExpressionPlan>, List<Boolean>, FuncSpec) - Constructor for class org.apache.pig.newplan.logical.relational.LOSort
 
LOSplit - Class in org.apache.pig.newplan.logical.relational
 
LOSplit(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOSplit
 
LOSplitOutput - Class in org.apache.pig.newplan.logical.relational
 
LOSplitOutput(LogicalPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOSplitOutput
 
LOSplitOutput(LogicalPlan, LogicalExpressionPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOSplitOutput
 
LOStore - Class in org.apache.pig.newplan.logical.relational
 
LOStore(LogicalPlan, FileSpec, StoreFuncInterface, String) - Constructor for class org.apache.pig.newplan.logical.relational.LOStore
 
LOStore(LogicalPlan, FileSpec, StoreFuncInterface, String, boolean) - Constructor for class org.apache.pig.newplan.logical.relational.LOStore
 
LOStream - Class in org.apache.pig.newplan.logical.relational
 
LOStream(LogicalPlan, ExecutableManager, StreamingCommand, LogicalSchema) - Constructor for class org.apache.pig.newplan.logical.relational.LOStream
 
LOStream.CastState - Enum in org.apache.pig.newplan.logical.relational
 
LOUnion - Class in org.apache.pig.newplan.logical.relational
 
LOUnion(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.relational.LOUnion
 
LOUnion(OperatorPlan, boolean) - Constructor for class org.apache.pig.newplan.logical.relational.LOUnion
 
LOWER - Class in org.apache.pig.builtin
LOWER implements eval function to convert a string to lower case Example: A = load 'mydata' as (name); B = foreach A generate LOWER(name);
LOWER() - Constructor for class org.apache.pig.builtin.LOWER
 
LOWER - Class in org.apache.pig.piggybank.evaluation.string
Deprecated.
Use LOWER
LOWER() - Constructor for class org.apache.pig.piggybank.evaluation.string.LOWER
Deprecated.
 
lp - Variable in class org.apache.pig.tools.ToolsPigServer.PigPlans
 
lr - Variable in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
LRs - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
lt_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
lt_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
lt_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat
 
lte_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
lte_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
lte_ - Variable in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat
 
LTOrEqualToExpr - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
LTOrEqualToExpr(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LTOrEqualToExpr
 
LTOrEqualToExpr(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LTOrEqualToExpr
 
LTRIM - Class in org.apache.pig.builtin
Returns a string, with only leading whitespace omitted.
LTRIM() - Constructor for class org.apache.pig.builtin.LTRIM
 

M

macros - Variable in class org.apache.pig.impl.PigContext
 
main(String[]) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.DiscreteProbabilitySampleGenerator
 
Main - Class in org.apache.pig
Main class for Pig engine.
Main() - Constructor for class org.apache.pig.Main
 
main(String[]) - Static method in class org.apache.pig.Main
The Main-Class for the Pig Jar that will provide a shell and setup a classpath appropriate for executing Jar files.
main(PigContext, String) - Method in class org.apache.pig.scripting.groovy.GroovyScriptEngine
 
main(PigContext, String) - Method in class org.apache.pig.scripting.jruby.JrubyScriptEngine
 
main(PigContext, String) - Method in class org.apache.pig.scripting.js.JsScriptEngine
 
main(PigContext, String) - Method in class org.apache.pig.scripting.jython.JythonScriptEngine
 
main(PigContext, String) - Method in class org.apache.pig.scripting.ScriptEngine
Actually runs the script file.
main(PigContext, String) - Method in class org.apache.pig.scripting.streaming.python.PythonScriptEngine
 
main(String[]) - Static method in class org.apache.pig.tools.streams.StreamGenerator
 
mainKeyType - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
make() - Method in class org.apache.pig.data.SchemaTuple.SchemaTupleQuickGenerator
 
make(A, B) - Static method in class org.apache.pig.data.utils.StructuresHelper.Pair
 
make(A, B, C) - Static method in class org.apache.pig.data.utils.StructuresHelper.Triple
 
makeDumper(DotMRPrinter.InnerPlan, PrintStream) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter
 
makeDumper(PhysicalPlan, PrintStream) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.DotPOPrinter
 
makeDumper(DotSparkPrinter.InnerPlan, PrintStream) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter
 
makeDumper(S, PrintStream) - Method in class org.apache.pig.impl.plan.DotPlanDumper
 
makeDumper(S, PrintStream) - Method in class org.apache.pig.impl.plan.PlanDumper
makeDumper is a factory method.
makeDumper(BaseOperatorPlan, PrintStream) - Method in class org.apache.pig.newplan.DotPlanDumper
 
makeDumper(BaseOperatorPlan, PrintStream) - Method in class org.apache.pig.newplan.logical.DotLOPrinter
 
makeDumper(BaseOperatorPlan, PrintStream) - Method in class org.apache.pig.newplan.PlanDumper
makeDumper is a factory method.
makeListener(Properties) - Static method in class org.apache.pig.Main
 
makeNameFromDataType(byte) - Method in class org.apache.pig.impl.util.NumValCarrier
 
makePair(String, String) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
makeStoreTmpPath(String) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.PlanHelper
Creates a relative path that can be used to build a temporary place to store the output from a number of map-reduce tasks.
mAlias - Variable in class org.apache.pig.tools.grunt.GruntParser.ExplainState
 
map(Text, Tuple, Mapper<Text, Tuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
The map function that attaches the inpTuple appropriately and executes the map plan if its not empty.
Map() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Map
 
Map() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapOnly.Map
 
map(Object...) - Static method in class org.apache.pig.builtin.mock.Storage
 
MAP - Static variable in class org.apache.pig.data.BinInterSedes
 
MAP - Static variable in class org.apache.pig.data.DataType
 
map(ThreadContext, IRubyObject, IRubyObject, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a ruby method which takes a name and an array of arguments and constructs a Map schema from them.
map(ThreadContext, IRubyObject, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a ruby method which takes an array of arguments and constructs a Map schema from them.
MAP_INPUT_RECORDS - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
 
MAP_MAX_ATTEMPTS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
MAP_OUTPUT_RECORDS - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
 
MAP_TASKS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
MAP_VALUE_FIELD - Static variable in class org.apache.pig.piggybank.storage.avro.AvroSchema2Pig
 
MapGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.MapGroovyAlgebraicEvalFunc
 
MapJrubyAlgebraicEvalFunc(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.MapJrubyAlgebraicEvalFunc
 
MapKeysInfo - Class in org.apache.pig.impl.plan
 
MapKeysInfo() - Constructor for class org.apache.pig.impl.plan.MapKeysInfo
 
MapKeysInfo(List<String>) - Constructor for class org.apache.pig.impl.plan.MapKeysInfo
 
MapKeysInfo(boolean) - Constructor for class org.apache.pig.impl.plan.MapKeysInfo
 
MapKeysInfo(boolean, List<String>) - Constructor for class org.apache.pig.impl.plan.MapKeysInfo
 
MapKeysPruneHelper - Class in org.apache.pig.newplan.logical.rules
This filter Marks every Load Operator which has a Map with MAP_MARKER_ANNOTATION.
MapKeysPruneHelper(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper
 
MapKeysPruneHelper.FullMapCollector - Class in org.apache.pig.newplan.logical.rules
 
MapKeysPruneHelper.MapMarker - Class in org.apache.pig.newplan.logical.rules
This class collects all the information required to create the list of keys required for a map
mapKeyType - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
mapKeyTypeOfSplittees - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
MapLookupExpression - Class in org.apache.pig.newplan.logical.expression
 
MapLookupExpression(OperatorPlan, String) - Constructor for class org.apache.pig.newplan.logical.expression.MapLookupExpression
 
MapMarker(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.MapMarker
 
MAPPER_NEW_API - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
mapPlan - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
MAPRED_DEFAULT_SITE - Static variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
MapRedResult - Class in org.apache.pig.backend.hadoop.executionengine
 
MapRedResult(FileSpec, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.MapRedResult
 
MAPREDUCE - Static variable in interface org.apache.pig.ExecType
 
MapReduceLauncher - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Main class that launches pig for Map Reduce
MapReduceLauncher() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceLauncher
 
MapReduceOper - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
An operator model for a Map Reduce job.
MapReduceOper(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
MapReducePartitionerWrapper - Class in org.apache.pig.backend.hadoop.executionengine.spark
Spark Partitioner that wraps a custom partitioner that implements org.apache.hadoop.mapreduce.Partitioner interface.
MapReducePartitionerWrapper(String, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.MapReducePartitionerWrapper
 
MapReducePOStoreImpl - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
This class is used to have a POStore write to DFS via a output collector/record writer.
MapReducePOStoreImpl(TaskInputOutputContext<?, ?, ?, ?>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReducePOStoreImpl
 
MapRedUtil - Class in org.apache.pig.backend.hadoop.executionengine.util
A class of utility static methods to be used in the hadoop map reduce backend
MapRedUtil() - Constructor for class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
 
MapSideMergeValidator - Class in org.apache.pig.newplan.logical.relational
 
MapSideMergeValidator() - Constructor for class org.apache.pig.newplan.logical.relational.MapSideMergeValidator
 
mapSideOnly - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
MapSize - Class in org.apache.pig.builtin
This method should never be used directly, use SIZE.
MapSize() - Constructor for class org.apache.pig.builtin.MapSize
 
MapSparkCounter() - Constructor for class org.apache.pig.tools.pigstats.spark.SparkCounter.MapSparkCounter
 
MapSparkCounter(String, String, String, Map<String, Long>, JavaSparkContext) - Constructor for class org.apache.pig.tools.pigstats.spark.SparkCounter.MapSparkCounter
 
MapSparkCounterGroup(String, String, JavaSparkContext) - Constructor for class org.apache.pig.tools.pigstats.spark.SparkCounterGroup.MapSparkCounterGroup
 
mapStores - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
 
mapToString(Map<String, Object>) - Static method in class org.apache.pig.data.DataType
Given a map, turn it into a String.
MapWithComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.MapWithComparator
 
MapWithPartitionIndex() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.MapWithPartitionIndex
 
mark(int) - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
mark() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl.IllustratorValueIterator
 
markBuildBloom() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markCastInserted(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.rules.LoadTypeCastInserter
 
markCastInserted(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.rules.StreamTypeCastInserter
 
markCastInserted(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.rules.TypeCastInserter
 
markCastNoNeed(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.rules.LoadTypeCastInserter
 
markCastNoNeed(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.rules.StreamTypeCastInserter
 
markCastNoNeed(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.rules.TypeCastInserter
 
markCogroup() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
markCogroup() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
markCogroup() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markDistinct() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markedAsShowToUser - Variable in exception org.apache.pig.PigException
 
markFilterBloom() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markGlobalSort() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markGroupBy() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
markGroupBy() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
markGroupBy() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markIndexer() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
markIndexer() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
markIndexer() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markIndexerInput() - Method in class org.apache.pig.tools.pigstats.InputStats
 
markJarAsPredeployed(String) - Method in class org.apache.pig.impl.PigContext
Adds the specified path to the predeployed jars list.
markLimit() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
markLimit() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markLimitAfterSort() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
markLimitAfterSort() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markNative() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
markNative() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markRankCounter() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markRegularJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
markRegularJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
markRegularJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markSampleAggregation() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markSampleBasedPartitioner() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markSampleInput() - Method in class org.apache.pig.tools.pigstats.InputStats
 
markSampler() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
markSampler() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
markSampler() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markSideFileInput() - Method in class org.apache.pig.tools.pigstats.InputStats
 
markSkewedJoin() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
markSpillableIfNecessary() - Method in class org.apache.pig.data.DefaultAbstractBag
All bag implementations that can get big enough to be spilled should call this method after every time they add an element.
markStale(boolean) - Method in class org.apache.pig.data.AccumulativeBag
 
markStale(boolean) - Method in interface org.apache.pig.data.DataBag
This is used by FuncEvalSpec.FakeDataBag.
markStale(boolean) - Method in class org.apache.pig.data.DefaultAbstractBag
This is used by FuncEvalSpec.FakeDataBag.
markStale(boolean) - Method in class org.apache.pig.data.LimitedSortedDataBag
Not implemented.
markStale(boolean) - Method in class org.apache.pig.data.NonSpillableDataBag
 
markStale(boolean) - Method in class org.apache.pig.data.ReadOnceBag
 
markStale(boolean) - Method in class org.apache.pig.data.SingleTupleBag
 
markStale(boolean) - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
markSupported() - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
markUnion() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
markUnion() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
mAsc - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigLongRawComparator
 
match(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex.CompiledAutomaton
 
match(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex.CompiledRegex
 
match(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex.NonConstantRegex
 
match(String, String) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex.RegexImpl
 
match(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex.RegexInit
 
match(OperatorPlan<? extends Operator<?>>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternPlan
Return true if the given plan has nodes that match the pattern represented by this class If a match is found, the PatterNodes in the plan will return non null node for getMatch().
match(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.WholePlanRule
 
match(OperatorPlan) - Method in class org.apache.pig.newplan.optimizer.Rule
Search for all the sub-plans that matches the pattern defined by this rule.
matchAll() - Method in class org.apache.pig.backend.hadoop.accumulo.Column
 
max(Tuple) - Static method in class org.apache.pig.builtin.DateTimeMax
 
MAX - Class in org.apache.pig.builtin
Generates the maximum of a set of values.
MAX() - Constructor for class org.apache.pig.builtin.MAX
 
max(Tuple) - Static method in class org.apache.pig.builtin.StringMax
 
MAX - Class in org.apache.pig.piggybank.evaluation.math
math.MAX implements a binding to the Java function Math.max(double,double).
MAX() - Constructor for class org.apache.pig.piggybank.evaluation.math.MAX
 
max(Tuple, PigProgressable) - Static method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField
 
max(DataBag, PigProgressable) - Static method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField
 
MAX.Final - Class in org.apache.pig.builtin
 
MAX.Intermediate - Class in org.apache.pig.builtin
 
MAX_DATAATOM_LENGTH - Static variable in class org.apache.pig.pen.util.DisplayExamples
 
MAX_LATENCY_OPTION - Static variable in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
MAX_REDUCER_COUNT_PARAM - Static variable in interface org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigReducerEstimator
 
MAX_SCRIPT_SIZE - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
use PigConfiguration.PIG_SCRIPT_MAX_SIZE instead. Will be removed in Pig 0.16
MAX_SPILL_FILES - Static variable in class org.apache.pig.data.DefaultAbstractBag
 
MAX_SPLIT_SIZE - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
MAX_TASKS - Static variable in class org.apache.pig.impl.streaming.StreamingCommand
 
maxIter - Variable in class org.apache.pig.newplan.optimizer.PlanOptimizer
 
maxLatency - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
maxMutationBufferSize - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
MaxTupleBy1stField - Class in org.apache.pig.piggybank.evaluation
MaxTupleBy1stField UDF returns a tuple with max value of the first field in a given bag.
MaxTupleBy1stField() - Constructor for class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField
 
MaxTupleBy1stField.Final - Class in org.apache.pig.piggybank.evaluation
 
MaxTupleBy1stField.Initial - Class in org.apache.pig.piggybank.evaluation
 
MaxTupleBy1stField.Intermediate - Class in org.apache.pig.piggybank.evaluation
 
maxWriteThreads - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
mBagFactory - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
mBagFactory - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
mBagFactory - Variable in class org.apache.pig.builtin.Utf8StorageConverter
 
mBagFactory - Static variable in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc
 
mContents - Variable in class org.apache.pig.data.DefaultAbstractBag
 
mCount - Variable in class org.apache.pig.tools.grunt.GruntParser.ExplainState
 
mCurrentWalker - Variable in class org.apache.pig.impl.plan.PlanVisitor
Guaranteed to always point to the walker currently being used.
mCustomPartitioner - Variable in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
Name of the customPartitioner if one is used, this is set to null otherwise.
memLimit - Variable in class org.apache.pig.data.SelfSpillBag
 
MemoryLimits(int, float) - Constructor for class org.apache.pig.data.SelfSpillBag.MemoryLimits
 
memToSkipPerSample - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
merge(Schema, boolean) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Merge this schema with the other schema
merge(OperatorPlan<E>) - Method in class org.apache.pig.impl.plan.OperatorPlan
Merges the operators in the incoming operPlan with this plan's operators.
merge(RequiredFields) - Method in class org.apache.pig.impl.plan.RequiredFields
Merge with RequiredFields r2.
merge(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionPlan
Merge all nodes in lgExpPlan, keep the connections
merge(LogicalSchema.LogicalFieldSchema, LogicalSchema.LogicalFieldSchema, LogicalSchema.MergeMode) - Static method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
Merge two LogicalFieldSchema, the behavior of merge depends on mode.
merge(LogicalSchema, LogicalSchema, LogicalSchema.MergeMode) - Static method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Merge two schemas.
MergeCogroupConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
MergeCogroupConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.MergeCogroupConverter
 
mergeCollection(Collection<O>, Collection<O>) - Static method in class org.apache.pig.impl.util.Utils
 
mergeConf(Configuration, Configuration) - Static method in class org.apache.pig.backend.hadoop.datastorage.ConfigurationUtil
 
MergeFilter - Class in org.apache.pig.newplan.logical.rules
 
MergeFilter(String) - Constructor for class org.apache.pig.newplan.logical.rules.MergeFilter
 
MergeFilter.MergeFilterTransformer - Class in org.apache.pig.newplan.logical.rules
 
MergeFilterTransformer() - Constructor for class org.apache.pig.newplan.logical.rules.MergeFilter.MergeFilterTransformer
 
MergeForEach - Class in org.apache.pig.newplan.logical.rules
 
MergeForEach(String) - Constructor for class org.apache.pig.newplan.logical.rules.MergeForEach
 
MergeForEach.MergeForEachTransformer - Class in org.apache.pig.newplan.logical.rules
 
MergeForEachTransformer() - Constructor for class org.apache.pig.newplan.logical.rules.MergeForEach.MergeForEachTransformer
 
MergeJoinConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
MergeJoinConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.MergeJoinConverter
 
MergeJoinIndexer - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Merge Join indexer is used to generate on the fly index for doing Merge Join efficiently.
MergeJoinIndexer(String, String, String, String, String, String) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MergeJoinIndexer
 
mergeMapKey(int, int, String) - Method in class org.apache.pig.impl.plan.RequiredFields
Merge another map key into existing required map keys list
mergeMapKeysInfo(int, int, MapKeysInfo) - Method in class org.apache.pig.impl.plan.RequiredFields
Merge a MapKeysInfo structure to existing required map keys list
mergePrefixFieldSchema(Schema.FieldSchema) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Recursively prefix merge two schemas
mergePrefixFieldSchema(Schema.FieldSchema, boolean) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Recursively prefix merge two schemas
mergePrefixFieldSchema(Schema.FieldSchema, boolean, boolean) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Recursively prefix merge two schemas
mergePrefixSchema(Schema, boolean) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Recursively prefix merge two schemas
mergePrefixSchema(Schema, boolean, boolean) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Recursively prefix merge two schemas
mergeSchema(Schema, Schema, boolean) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
Recursively merge two schemas
mergeSchema(Schema, Schema, boolean, boolean, boolean) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
Recursively merge two schemas
mergeSchema(Schema, Schema) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
This method merges two avro schemas into one.
mergeSchemaByAlias(Schema, Schema) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
Merges two schemas using their column aliases (unlike mergeSchema(..) functions which merge using positions) Schema will not be merged if types are incompatible, as per DataType.mergeType(..) For Tuples and Bags, SubSchemas have to be equal be considered compatible
mergeSchemaByAlias(LogicalSchema, LogicalSchema) - Static method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Merges two schemas using their column aliases (unlike mergeSchema(..) functions which merge using positions) Schema will not be merged if types are incompatible, as per DataType.mergeType(..) For Tuples and Bags, SubSchemas have to be equal be considered compatible
mergeSchemasByAlias(Collection<Schema>) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
Merges collection of schemas using their column aliases (unlike mergeSchema(..) functions which merge using positions) Schema will not be merged if types are incompatible, as per DataType.mergeType(..) For Tuples and Bags, SubSchemas have to be equal be considered compatible
mergeSchemasByAlias(List<LogicalSchema>) - Static method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Merges collection of schemas using their column aliases (unlike mergeSchema(..) functions which merge using positions) Schema will not be merged if types are incompatible, as per DataType.mergeType(..) For Tuples and Bags, SubSchemas have to be equal be considered compatible
mergeSharedPlan(OperatorPlan<E>) - Method in class org.apache.pig.impl.plan.OperatorPlan
Merges the operators in the incoming plan with this plan's operators.
mergeType(byte, byte) - Static method in class org.apache.pig.data.DataType
Merge types if possible.
mergeUid(LogicalSchema.LogicalFieldSchema) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
Adds the uid from FieldSchema argument to this FieldSchema If the argument is null, it stamps this FieldSchema with uid
mergeUid(LogicalSchema) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
 
Message(String, CompilationMessageCollector.MessageType) - Constructor for class org.apache.pig.impl.plan.CompilationMessageCollector.Message
 
Message(String, CompilationMessageCollector.MessageType, Enum) - Constructor for class org.apache.pig.impl.plan.CompilationMessageCollector.Message
 
method - Variable in class org.apache.pig.scripting.groovy.GroovyEvalFunc
 
MethodHelper - Class in org.apache.pig.data.utils
 
MethodHelper.NotImplemented - Annotation Type in org.apache.pig.data.utils
This is an annotation which allows a class to signal that while it is "implementing" a method because it is specified by a parent class or interface, that the implementation just throws an exception, because it is not implemented.
methodNotImplemented() - Static method in class org.apache.pig.data.utils.MethodHelper
 
methodSignatureEqual(Method, Method) - Static method in class org.apache.pig.data.utils.MethodHelper
This implements a stripped down version of method equality.
MetricEvaluation - Class in org.apache.pig.pen.util
 
MetricEvaluation() - Constructor for class org.apache.pig.pen.util.MetricEvaluation
 
mFakeTuple - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
mFields - Variable in class org.apache.pig.data.DefaultTuple
 
mFormat - Variable in class org.apache.pig.tools.grunt.GruntParser.ExplainState
 
mFromEdges - Variable in class org.apache.pig.impl.plan.OperatorPlan
 
MilliSecondsBetween - Class in org.apache.pig.builtin
MilliSecondsBetween returns the number of milliseconds between two DateTime objects
MilliSecondsBetween() - Constructor for class org.apache.pig.builtin.MilliSecondsBetween
 
min(Tuple) - Static method in class org.apache.pig.builtin.DateTimeMin
 
MIN - Class in org.apache.pig.builtin
Generates the minimum of a set of values.
MIN() - Constructor for class org.apache.pig.builtin.MIN
 
min(Tuple) - Static method in class org.apache.pig.builtin.StringMin
 
MIN - Class in org.apache.pig.piggybank.evaluation.math
math.MIN implements a binding to the Java function Math.min(double,double).
MIN() - Constructor for class org.apache.pig.piggybank.evaluation.math.MIN
 
MIN.Final - Class in org.apache.pig.builtin
 
MIN.Intermediate - Class in org.apache.pig.builtin
 
MinutesBetween - Class in org.apache.pig.builtin
MinutesBetween returns the number of minutes between two DateTime objects
MinutesBetween() - Constructor for class org.apache.pig.builtin.MinutesBetween
 
mIsDistinct - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
mkdirs(String) - Method in class org.apache.pig.PigServer
Make a directory.
mKey - Variable in class org.apache.pig.impl.plan.Operator
OperatorKey associated with this operator.
mKeys - Variable in class org.apache.pig.impl.plan.OperatorPlan
 
mLast - Variable in class org.apache.pig.tools.grunt.GruntParser.ExplainState
 
mLog - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigLongRawComparator
 
mLog - Variable in class org.apache.pig.builtin.PigStorage
 
mLog - Variable in class org.apache.pig.builtin.TextLoader
 
mLog - Variable in class org.apache.pig.builtin.Utf8StorageConverter
 
mLog - Static variable in class org.apache.pig.impl.util.CastUtils
 
mLog - Static variable in class org.apache.pig.impl.util.TupleFormat
 
mMap - Variable in class org.apache.pig.impl.util.MultiMap
 
mMultiInputSubgraphs - Variable in class org.apache.pig.impl.plan.DotPlanDumper
 
mMultiInputSubgraphs - Variable in class org.apache.pig.newplan.DotPlanDumper
 
mMultiOutputSubgraphs - Variable in class org.apache.pig.impl.plan.DotPlanDumper
 
mMultiOutputSubgraphs - Variable in class org.apache.pig.newplan.DotPlanDumper
 
Mod - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
Mod(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Mod
 
Mod(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Mod
 
mod(Number, Number, byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Mod
 
ModExpression - Class in org.apache.pig.newplan.logical.expression
Mod Operator
ModExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.ModExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
MODIFICATION_TIME_KEY - Static variable in interface org.apache.pig.backend.datastorage.ElementDescriptor
Available from getStatistics as a Long.
MonitoredUDF - Annotation Type in org.apache.pig.builtin
Describes how the execution of a UDF should be monitored, and what to do if it times out.
MonitoredUDFExecutor - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.util
MonitoredUDF is used to watch execution of a UDF, and kill it if the UDF takes an exceedingly long time.
MonitoredUDFExecutor(EvalFunc) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.MonitoredUDFExecutor
 
MonitoredUDFExecutor.ErrorCallback - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.util
UDF authors can optionally extend this class and provide the class of their custom callbacks in the annotation to perform their own handling of errors and timeouts.
monitorExec(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.MonitoredUDFExecutor
 
MonthsBetween - Class in org.apache.pig.builtin
MonthsBetween returns the number of months between two DateTime objects
MonthsBetween() - Constructor for class org.apache.pig.builtin.MonthsBetween
 
mOps - Variable in class org.apache.pig.impl.plan.OperatorPlan
 
moreSpecificThan(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SortKeyInfo
 
moveResults(List<Job>) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
Moves all the results of a collection of MR jobs to the final output directory.
moveTree(TezOperator, TezOperPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperPlan
Move everything below a given operator to the new operator plan.
moveTree(Operator, BaseOperatorPlan) - Method in class org.apache.pig.newplan.BaseOperatorPlan
Move everything below a given operator to the new operator plan.
mp - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
 
mPinnedOptions - Variable in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
A HashSet to indicate whether an option (such a Join Type) was pinned by the user or can be chosen at runtime by the optimizer.
mPlan - Variable in class org.apache.pig.impl.plan.PlanVisitor
 
mPlan - Variable in class org.apache.pig.impl.plan.PlanWalker
 
mqFlag - Static variable in class org.apache.pig.impl.io.PigNullableWritable
indices in multiquery optimized maps will have the Most Significant Bit set This is a bitmask used in those cases.
MRCompiler - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
The compiler that compiles a given physical plan into a DAG of MapReduce operators which can then be converted into the JobControl structure.
MRCompiler(PhysicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
MRCompiler(PhysicalPlan, PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
MRCompilerException - Exception in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
MRCompilerException() - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompilerException
Create a new MRCompilerException with null as the error message.
MRCompilerException(String) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompilerException
Create a new MRCompilerException with the specified message and cause.
MRCompilerException(Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompilerException
Create a new MRCompilerException with the specified cause.
MRCompilerException(String, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompilerException
Create a new MRCompilerException with the specified message and cause.
MRCompilerException(String, int) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompilerException
Create a new MRCompilerException with the specified message and cause.
MRCompilerException(String, int, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompilerException
Create a new MRCompilerException with the specified message and cause.
MRCompilerException(String, int, byte) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompilerException
Create a new MRCompilerException with the specified message and cause.
MRCompilerException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompilerException
Create a new MRCompilerException with the specified message and cause.
MRCompilerException(String, int, boolean) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompilerException
Create a new MRCompilerException with the specified message and cause.
MRCompilerException(String, int, byte, boolean) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompilerException
Create a new MRCompilerException with the specified message and cause.
MRCompilerException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompilerException
Create a new MRCompilerException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
MRCompilerException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompilerException
Create a new MRCompilerException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
MRConfiguration - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
MRConfiguration() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
mRequiredColumns - Variable in class org.apache.pig.builtin.OrcStorage
 
mRequiredColumns - Variable in class org.apache.pig.builtin.PigStorage
 
MRExecType - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
MRExecType is the ExecType for distributed mode in Hadoop Mapreduce.
MRExecType() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRExecType
 
MRExecutionEngine - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
MRExecutionEngine(PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRExecutionEngine
 
MRIntermediateDataVisitor - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
An MROpPlanVisitor that gathers the paths for all intermediate data from a MROperPlan
MRIntermediateDataVisitor(MROperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.MRIntermediateDataVisitor
 
MRJobStats - Class in org.apache.pig.tools.pigstats.mapreduce
This class encapsulates the runtime statistics of a MapReduce job.
MROperPlan - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
A Plan used to create the plan of Map Reduce Operators which can be converted into the Job Control object.
MROperPlan() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.MROperPlan
 
MROpPlanVisitor - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
A visitor for the MROperPlan class
MROpPlanVisitor(MROperPlan, PlanWalker<MapReduceOper, MROperPlan>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.MROpPlanVisitor
 
MRPigStatsUtil - Class in org.apache.pig.tools.pigstats.mapreduce
A utility class for Pig Statistics
MRPigStatsUtil() - Constructor for class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
 
MRPrinter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
A visitor mechanism printing out the logical plan.
MRPrinter(PrintStream, MROperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.MRPrinter
 
MRScriptState - Class in org.apache.pig.tools.pigstats.mapreduce
ScriptStates encapsulates settings for a Pig script that runs on a hadoop cluster.
MRScriptState(String) - Constructor for class org.apache.pig.tools.pigstats.mapreduce.MRScriptState
 
MRTaskContext - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
MRTaskContext(TaskInputOutputContext<?, ?, ?, ?>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRTaskContext
 
MRToTezHelper - Class in org.apache.pig.backend.hadoop.executionengine.tez.util
 
MRUtil - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
MRUtil() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRUtil
 
mScript - Variable in class org.apache.pig.tools.grunt.GruntParser.ExplainState
 
msgHeader() - Method in exception org.apache.pig.parser.PigRecognitionException
 
mSize - Variable in class org.apache.pig.data.DefaultAbstractBag
 
mSoftFromEdges - Variable in class org.apache.pig.impl.plan.OperatorPlan
 
mSoftToEdges - Variable in class org.apache.pig.impl.plan.OperatorPlan
 
mSpillFiles - Variable in class org.apache.pig.data.DefaultAbstractBag
 
mSubgraphs - Variable in class org.apache.pig.impl.plan.DotPlanDumper
 
mSubgraphs - Variable in class org.apache.pig.newplan.DotPlanDumper
 
mTarget - Variable in class org.apache.pig.tools.grunt.GruntParser.ExplainState
 
mTime - Variable in class org.apache.pig.tools.grunt.GruntParser.ExplainState
 
mToEdges - Variable in class org.apache.pig.impl.plan.OperatorPlan
 
mTupleFactory - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
mTupleFactory - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
mTupleFactory - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
mTupleFactory - Variable in class org.apache.pig.builtin.Utf8StorageConverter
 
mTupleFactory - Variable in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
mTupleFactory - Static variable in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc
 
MULTI_INPUTS_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
 
MULTI_INPUTS_RECORD_COUNTER - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
 
MULTI_STORE_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
 
MULTI_STORE_RECORD_COUNTER - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
 
MultiMap<K,V> - Class in org.apache.pig.impl.util
An implementation of multi-map.
MultiMap() - Constructor for class org.apache.pig.impl.util.MultiMap
 
MultiMap(int) - Constructor for class org.apache.pig.impl.util.MultiMap
 
Multiply - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
Multiply(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
Multiply(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
multiply(Number, Number, byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
MultiplyExpression - Class in org.apache.pig.newplan.logical.expression
Multiply Operator
MultiplyExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.MultiplyExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
MultiQueryOptimizerSpark - Class in org.apache.pig.backend.hadoop.executionengine.spark.optimizer
MultiQueryOptimizer for spark
MultiQueryOptimizerSpark(SparkOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.MultiQueryOptimizerSpark
 
MultiQueryOptimizerTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
 
MultiQueryOptimizerTez(TezOperPlan, boolean, List<String>, List<String>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.MultiQueryOptimizerTez
 
MultiQueryPackager - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The package operator that packages the globally rearranged tuples into output format as required by multi-query de-multiplexer.
MultiQueryPackager() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
 
MultiStorage - Class in org.apache.pig.piggybank.storage
The UDF is useful for splitting the output data into a bunch of directories and files dynamically based on user specified key field in the output tuple.
MultiStorage(String, String) - Constructor for class org.apache.pig.piggybank.storage.MultiStorage
 
MultiStorage(String, String, String) - Constructor for class org.apache.pig.piggybank.storage.MultiStorage
 
MultiStorage(String, String, String, String) - Constructor for class org.apache.pig.piggybank.storage.MultiStorage
 
MultiStorage(String, String, String, String, String) - Constructor for class org.apache.pig.piggybank.storage.MultiStorage
Constructor
MultiStorage.MultiStorageOutputFormat - Class in org.apache.pig.piggybank.storage
 
MultiStorage.MultiStorageOutputFormat.MyLineRecordWriter - Class in org.apache.pig.piggybank.storage
 
MultiStorageOutputFormat() - Constructor for class org.apache.pig.piggybank.storage.MultiStorage.MultiStorageOutputFormat
 
MUTATION_BUFFER_SIZE_OPTION - Static variable in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
mValue - Variable in class org.apache.pig.impl.io.PigNullableWritable
 
mVerbose - Variable in class org.apache.pig.tools.grunt.GruntParser.ExplainState
 
mWrappedComp - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigLongRawComparator
 
MyLineRecordWriter(DataOutputStream, String) - Constructor for class org.apache.pig.piggybank.storage.MultiStorage.MultiStorageOutputFormat.MyLineRecordWriter
 
MyRegExLoader - Class in org.apache.pig.piggybank.storage
 
MyRegExLoader(String) - Constructor for class org.apache.pig.piggybank.storage.MyRegExLoader
 

N

name() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.LocalExecType
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
Uses the string representation of the component plans to identify itself.
name() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRExecType
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.NativeMapReduceOper
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter.InnerOperator
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.EqualToExpr
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GreaterThanExpr
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GTOrEqualToExpr
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LessThanExpr
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LTOrEqualToExpr
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Mod
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.NotEqualToExpr
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POAnd
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POIsNull
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONot
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POOr
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORegexp
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORelationToExprProject
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.JoinPackager
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POBroadcastSpark
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoinSpark
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PONative
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POOptimizedForEach
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartitionRearrange
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POReservoirSample
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSortedDistinct
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POJoinGroupSpark
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POPoissonSampleSpark
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POSampleSortSpark
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter.InnerOperator
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkExecType
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkLocalExecType
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.NativeTezOper
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBloomFilterRearrangeTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POFRJoinTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POIdentityInOutTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POPartitionRearrangeTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.PORankTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffledValueInputTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POStoreTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueInputTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerNode
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezExecType
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezLocalExecType
 
name() - Method in interface org.apache.pig.ExecType
Returns the canonical name for this ExecType.
name() - Method in class org.apache.pig.impl.plan.Operator
 
name - Variable in class org.apache.pig.newplan.Operator
 
name - Variable in class org.apache.pig.newplan.optimizer.Rule
 
NAMESPACE_SEPARATOR - Static variable in class org.apache.pig.scripting.ScriptEngine
 
NativeMapReduceOper - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
NativeMapReduceOper(OperatorKey, String, String[]) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.NativeMapReduceOper
 
NativeSparkOperator - Class in org.apache.pig.backend.hadoop.executionengine.spark.operator
NativeSparkOperator:
NativeSparkOperator(OperatorKey, String, String[]) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.operator.NativeSparkOperator
 
NativeTezOper - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
 
NativeTezOper(OperatorKey, String, String[]) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.NativeTezOper
 
needAllFields() - Method in class org.apache.pig.impl.plan.RequiredFields
 
needAllKeys() - Method in class org.apache.pig.impl.plan.MapKeysInfo
 
needEndOfAllInputProcessing() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.UDFEndOfAllInputNeededVisitor
 
needEndOfAllInputProcessing() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
needEndOfAllInputProcessing() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
needEndOfAllInputProcessing() - Method in class org.apache.pig.builtin.HiveUDTF
 
needEndOfAllInputProcessing() - Method in class org.apache.pig.EvalFunc
 
needNoFields() - Method in class org.apache.pig.impl.plan.RequiredFields
 
needsDistinctCombiner() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
needsDistinctCombiner() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
needSegmentBelow() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
NEGATIVE_INFINITY() - Static method in class org.apache.pig.builtin.BigDecimalWrapper
 
NEGATIVE_INFINITY() - Static method in class org.apache.pig.builtin.BigIntegerWrapper
 
NegativeExpression - Class in org.apache.pig.newplan.logical.expression
 
NegativeExpression(OperatorPlan, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.NegativeExpression
 
nested - Variable in class org.apache.pig.newplan.logical.relational.LOCross
 
NestedLimitOptimizer - Class in org.apache.pig.newplan.logical.rules
 
NestedLimitOptimizer(String) - Constructor for class org.apache.pig.newplan.logical.rules.NestedLimitOptimizer
 
NestedLimitOptimizer.OptimizeNestedLimitTransformer - Class in org.apache.pig.newplan.logical.rules
 
neverUseForRealSetFieldSchema(LogicalSchema.LogicalFieldSchema) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpression
 
neverUseForRealSetSchema(LogicalSchema) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
Only to be used by unit tests.
newArray(Object, int, Schema) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumReader
Called to create new array instances.
newBagSchema(String, String, List<String>, List<Byte>) - Static method in class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
Create a bag schema according the bag name,tuple name and two list: name of fields, type of fields
newBagSchema(String, String, String[], Byte[]) - Static method in class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
 
newBagSchema(List<String>, List<Byte>) - Static method in class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
Create a bag schema according two list: name of fields, type of fields, and the default bag name is b, the default tuple name is t.
newBagSchema(List<Byte>) - Static method in class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
Create a new tuple schema according one list: types of fields, the default names of fields are f0,f1,f2..., and the tuple is t, the bag name is b.
newBagSchema(String[], Byte[]) - Static method in class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
Create a new tuple schema according two arrays: names of field,types of fields.
newBagSchema(Byte[]) - Static method in class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
Create a new tuple schema according one array: the type of fields, the tuple name is t, and the bag name is b.
newDefaultBag() - Method in class org.apache.pig.data.BagFactory
Get a default (unordered, not distinct) data bag.
newDefaultBag(List<Tuple>) - Method in class org.apache.pig.data.BagFactory
Get a default (unordered, not distinct) data bag with an existing list of tuples inserted into the bag.
newDefaultBag() - Method in class org.apache.pig.data.DefaultBagFactory
Get a default (unordered, not distinct) data bag.
newDefaultBag(List<Tuple>) - Method in class org.apache.pig.data.DefaultBagFactory
Get a default (unordered, not distinct) data bag from an existing list of tuples.
newDistinctBag() - Method in class org.apache.pig.data.BagFactory
Get a distinct data bag.
newDistinctBag() - Method in class org.apache.pig.data.DefaultBagFactory
Get a distinct data bag.
newJobConf(PigContext, PhysicalPlan, SparkEngineConf) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkUtil
 
newLimitedSortedBag(Comparator<Tuple>, long) - Method in class org.apache.pig.data.BagFactory
Get a limited sorted data bag.
newLimitedSortedBag(Comparator<Tuple>, long) - Method in class org.apache.pig.data.DefaultBagFactory
Get a limited sorted data bag.
newLogToPhyMap - Variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
newOperatorKey(String) - Static method in class org.apache.pig.parser.LogicalPlanBuilder
 
newRecord(Object, Schema) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumReader
Called to create new record instances.
newSample - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
newSchemaFromRequiredFieldList(Schema, LoadPushDown.RequiredFieldList) - Static method in class org.apache.pig.impl.util.avro.AvroStorageSchemaConversionUtilities
Takes an Avro Schema and a Pig RequiredFieldList and returns a new schema with only the requried fields, or no if the function can't extract only those fields.
newSchemaFromRequiredFieldList(Schema, List<LoadPushDown.RequiredField>) - Static method in class org.apache.pig.impl.util.avro.AvroStorageSchemaConversionUtilities
Takes an Avro Schema and a Pig RequiredFieldList and returns a new schema with only the required fields, or no if the function can't extract only those fields.
newSchemaTupleFactory(Schema, boolean, SchemaTupleClassGenerator.GenContext) - Static method in class org.apache.pig.data.SchemaTupleBackend
 
newSchemaTupleFactory(int) - Static method in class org.apache.pig.data.SchemaTupleBackend
 
newSortedBag(Comparator<Tuple>) - Method in class org.apache.pig.data.BagFactory
Get a sorted data bag.
newSortedBag(Comparator<Tuple>) - Method in class org.apache.pig.data.DefaultBagFactory
Get a sorted data bag.
newTuple() - Method in class org.apache.pig.data.BinSedesTupleFactory
 
newTuple(int) - Method in class org.apache.pig.data.BinSedesTupleFactory
 
newTuple(List) - Method in class org.apache.pig.data.BinSedesTupleFactory
 
newTuple(Object) - Method in class org.apache.pig.data.BinSedesTupleFactory
 
newTuple() - Method in class org.apache.pig.data.SchemaTupleFactory
 
newTuple(int) - Method in class org.apache.pig.data.SchemaTupleFactory
 
newTuple() - Method in class org.apache.pig.data.TupleFactory
Create an empty tuple.
newTuple(int) - Method in class org.apache.pig.data.TupleFactory
Create a tuple with size fields.
newTuple(List) - Method in class org.apache.pig.data.TupleFactory
Create a tuple from the provided list of objects.
newTuple(Object) - Method in class org.apache.pig.data.TupleFactory
Create a tuple with a single element.
newTuple() - Method in interface org.apache.pig.data.TupleMaker
 
newTuple(int) - Method in interface org.apache.pig.data.TupleMaker
 
newTupleNoCopy(List) - Method in class org.apache.pig.data.BinSedesTupleFactory
 
newTupleNoCopy(List) - Method in class org.apache.pig.data.TupleFactory
Create a tuple from a provided list of objects, keeping the provided list.
newTupleSchema(String, List<String>, List<Byte>) - Static method in class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
Create a new tuple schema according the tuple name and two list: names of fields, types of fields
newTupleSchema(String, String[], Byte[]) - Static method in class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
Create a new tuple schema according the tuple name and two arrays: names of fields, types of fields
newTupleSchema(List<String>, List<Byte>) - Static method in class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
Create a new tuple schema according the two list: names of fields, types of fields, the default tuple name is t.
newTupleSchema(List<Byte>) - Static method in class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
Create a new tuple schema according one list: types of fields, the default names of fields are f0,f1,f2..., and the tuple name is t.
newTupleSchema(String[], Byte[]) - Static method in class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
Create a new tuple schema according the two arrays: names of fields, types of fields, the default tuple name is t.
newTupleSchema(Byte[]) - Static method in class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
Create a new tuple schema according one array: types of fields, the default names of fields are f0,f1,f2..., and the tuple name is t.
next() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl.IllustratorValueIterator
 
next() - Method in class org.apache.pig.data.ReadOnceBag.ReadOnceBagIterator
 
next() - Method in class org.apache.pig.impl.util.RewindableIterator
 
next() - Method in class org.apache.pig.pen.FakeRawKeyValueIterator
 
next() - Method in class org.apache.pig.scripting.groovy.GroovyUtils.DataBagGroovyIterator
 
nextAfter - Class in org.apache.pig.piggybank.evaluation.math
math.nextAfter implements a binding to the Java function Math.nextAfter(double,double).
nextAfter() - Constructor for class org.apache.pig.piggybank.evaluation.math.nextAfter
 
nextBatch() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.AccumulativeTupleBuffer
Pull next batch of tuples from iterator and put them into this buffer
nextBatch() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage.POPackageTupleBuffer
 
nextKey() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl
 
nextKeyValue() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase.IllustratorContext
 
nextKeyValue() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigRecordReader
 
nextKeyValue() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableRecordReader
 
nextKeyValue() - Method in class org.apache.pig.impl.io.BinStorageRecordReader
 
nextKeyValue() - Method in class org.apache.pig.impl.io.InterRecordReader
 
nextKeyValue() - Method in class org.apache.pig.impl.io.TFileRecordReader
 
nextKeyValue() - Method in class org.apache.pig.impl.util.avro.AvroArrayReader
 
nextKeyValue() - Method in class org.apache.pig.impl.util.avro.AvroRecordReader
 
nextKeyValue() - Method in class org.apache.pig.piggybank.storage.AllLoader.AllReader
 
nextKeyValue() - Method in class org.apache.pig.piggybank.storage.avro.PigAvroRecordReader
 
nextKeyValue() - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCRecordReader
 
nextKeyValue() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader
 
nextKeyValue() - Method in class org.apache.pig.piggybank.storage.XMLLoader.XMLRecordReader
 
nextSampleIdx - Variable in class org.apache.pig.impl.builtin.RandomSampleLoader
 
NEXTUP - Class in org.apache.pig.piggybank.evaluation.math
math.NEXTUP implements a binding to the Java function Math.nextUp(double).
NEXTUP() - Constructor for class org.apache.pig.piggybank.evaluation.math.NEXTUP
 
noCombineSmallSplits() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
noCombineSmallSplits() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
noCombineSmallSplits() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
node() - Method in class org.apache.pig.parser.SourceLocation
 
nodeGen - Variable in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
nodeGen - Variable in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
NodeIdGenerator - Class in org.apache.pig.impl.plan
Generates IDs as long values in a thread safe manner.
noDir(FileStatus[]) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
check whether there is NO directory in the input file (status) list
noItems - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
NonConstantRegex - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex
 
NonConstantRegex() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex.NonConstantRegex
 
Nondeterministic - Annotation Type in org.apache.pig.builtin
A non-deterministic UDF is one that can produce different results when invoked on the same input.
NonEmptyOrcFileFilter(FileSystem) - Constructor for class org.apache.pig.builtin.OrcStorage.NonEmptyOrcFileFilter
 
NonFSLoadFunc - Interface in org.apache.pig
Marker interface to distinguish LoadFunc implementations that don't use file system sources.
NonProjectExpressionException - Exception in org.apache.pig.parser
 
NonProjectExpressionException(IntStream, SourceLocation, LogicalExpression) - Constructor for exception org.apache.pig.parser.NonProjectExpressionException
 
NonSpillableDataBag - Class in org.apache.pig.data
An unordered collection of Tuples (possibly) with multiples.
NonSpillableDataBag() - Constructor for class org.apache.pig.data.NonSpillableDataBag
 
NonSpillableDataBag(int) - Constructor for class org.apache.pig.data.NonSpillableDataBag
Use this constructor if you know upfront how many tuples you are going to put in this bag.
NonSpillableDataBag(List<Tuple>) - Constructor for class org.apache.pig.data.NonSpillableDataBag
This constructor creates a bag out of an existing list of tuples by taking ownership of the list and NOT copying the contents of the list.
NoopFilterRemover - Class in org.apache.pig.backend.hadoop.executionengine.spark.optimizer
For historical reasons splits will always produce filters that pass everything through unchanged.
NoopFilterRemover(SparkOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.NoopFilterRemover
 
NoopFilterRemover - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
For historical reasons splits will always produce filters that pass everything through unchanged.
NoopFilterRemover(TezOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.NoopFilterRemover
 
NoopFilterRemoverUtil - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
NoopFilterRemoverUtil() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.NoopFilterRemoverUtil
 
noRewind() - Method in class org.apache.pig.impl.util.RewindableIterator
 
normalize() - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
Old Pig field schema does not require a tuple schema inside a bag; Now it is required to have that; this method is to fill the gap
normalize() - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Old Pig schema does not require a tuple schema inside a bag; Now it is required to have that; this method is to fill the gap
NotEqualExpression - Class in org.apache.pig.newplan.logical.expression
NotEquality test expression.
NotEqualExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.NotEqualExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
NotEqualToExpr - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
NotEqualToExpr(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.NotEqualToExpr
 
NotEqualToExpr(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.NotEqualToExpr
 
NotExpression - Class in org.apache.pig.newplan.logical.expression
 
NotExpression(OperatorPlan, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.NotExpression
 
NOTNULL - Static variable in interface org.apache.pig.data.Tuple
Marker for indicating whether the value this object holds is not a null
npe(NullPointerException, String) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
As of Avro 1.5.1 this method is now in the superclass so it's no longer needed here, but leaving here for backward compatibility with Avro 1.4.1.
NULL - Static variable in class org.apache.pig.data.BinInterSedes
 
NULL - Static variable in class org.apache.pig.data.DataType
 
NULL - Static variable in interface org.apache.pig.data.Tuple
Marker for indicating whether the value this object holds is a null
NullableBag - Class in org.apache.pig.impl.io
 
NullableBag() - Constructor for class org.apache.pig.impl.io.NullableBag
 
NullableBag(DataBag) - Constructor for class org.apache.pig.impl.io.NullableBag
 
NullableBigDecimalWritable - Class in org.apache.pig.impl.io
 
NullableBigDecimalWritable() - Constructor for class org.apache.pig.impl.io.NullableBigDecimalWritable
 
NullableBigDecimalWritable(BigDecimal) - Constructor for class org.apache.pig.impl.io.NullableBigDecimalWritable
 
NullableBigIntegerWritable - Class in org.apache.pig.impl.io
 
NullableBigIntegerWritable() - Constructor for class org.apache.pig.impl.io.NullableBigIntegerWritable
 
NullableBigIntegerWritable(BigInteger) - Constructor for class org.apache.pig.impl.io.NullableBigIntegerWritable
 
NullableBooleanWritable - Class in org.apache.pig.impl.io
 
NullableBooleanWritable() - Constructor for class org.apache.pig.impl.io.NullableBooleanWritable
 
NullableBooleanWritable(boolean) - Constructor for class org.apache.pig.impl.io.NullableBooleanWritable
 
NullableBytesWritable - Class in org.apache.pig.impl.io
 
NullableBytesWritable() - Constructor for class org.apache.pig.impl.io.NullableBytesWritable
 
NullableBytesWritable(Object) - Constructor for class org.apache.pig.impl.io.NullableBytesWritable
 
NullableDateTimeWritable - Class in org.apache.pig.impl.io
 
NullableDateTimeWritable() - Constructor for class org.apache.pig.impl.io.NullableDateTimeWritable
 
NullableDateTimeWritable(DateTime) - Constructor for class org.apache.pig.impl.io.NullableDateTimeWritable
 
NullableDoubleWritable - Class in org.apache.pig.impl.io
 
NullableDoubleWritable() - Constructor for class org.apache.pig.impl.io.NullableDoubleWritable
 
NullableDoubleWritable(double) - Constructor for class org.apache.pig.impl.io.NullableDoubleWritable
 
NullableFloatWritable - Class in org.apache.pig.impl.io
 
NullableFloatWritable() - Constructor for class org.apache.pig.impl.io.NullableFloatWritable
 
NullableFloatWritable(float) - Constructor for class org.apache.pig.impl.io.NullableFloatWritable
 
NullableIntWritable - Class in org.apache.pig.impl.io
 
NullableIntWritable() - Constructor for class org.apache.pig.impl.io.NullableIntWritable
 
NullableIntWritable(int) - Constructor for class org.apache.pig.impl.io.NullableIntWritable
 
NullableLongWritable - Class in org.apache.pig.impl.io
 
NullableLongWritable() - Constructor for class org.apache.pig.impl.io.NullableLongWritable
 
NullableLongWritable(long) - Constructor for class org.apache.pig.impl.io.NullableLongWritable
 
NullablePartitionWritable - Class in org.apache.pig.impl.io
NullablePartitionWritable is an adaptor class around PigNullableWritable that adds a partition index to the class.
NullablePartitionWritable() - Constructor for class org.apache.pig.impl.io.NullablePartitionWritable
 
NullablePartitionWritable(PigNullableWritable) - Constructor for class org.apache.pig.impl.io.NullablePartitionWritable
 
NullableText - Class in org.apache.pig.impl.io
 
NullableText() - Constructor for class org.apache.pig.impl.io.NullableText
 
NullableText(byte[]) - Constructor for class org.apache.pig.impl.io.NullableText
 
NullableText(String) - Constructor for class org.apache.pig.impl.io.NullableText
 
NullableTuple - Class in org.apache.pig.impl.io
 
NullableTuple() - Constructor for class org.apache.pig.impl.io.NullableTuple
 
NullableTuple(Tuple) - Constructor for class org.apache.pig.impl.io.NullableTuple
 
NullableTuple(NullableTuple) - Constructor for class org.apache.pig.impl.io.NullableTuple
 
NullableUnknownWritable - Class in org.apache.pig.impl.io
This class can be used when data type is 'Unknown' and there is a need for PigNullableWritable object.
NullableUnknownWritable() - Constructor for class org.apache.pig.impl.io.NullableUnknownWritable
 
NullableUnknownWritable(WritableComparable<?>) - Constructor for class org.apache.pig.impl.io.NullableUnknownWritable
 
nullBag - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
nullBag(ThreadContext, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a static helper method to create a null aliased bag Schema.
nullBoolean(ThreadContext, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a static helper method to create a null aliased Boolean Schema.
nullBytearray(ThreadContext, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a static helper method to create a null aliased bytearray Schema.
nullChararray(ThreadContext, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a static helper method to create a null aliased chararray Schema.
nullDateTime(ThreadContext, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a static helper method to create a null aliased datetime Schema.
nullDouble(ThreadContext, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a static helper method to create a null aliased double Schema.
nullFloate(ThreadContext, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a static helper method to create a null aliased float Schema.
nullInt(ThreadContext, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a static helper method to create a null aliased int Schema.
nullLong(ThreadContext, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a static helper method to create a null aliased long Schema.
nullMap(ThreadContext, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a static helper method to create a null aliased map Schema.
NULLPART_JOB_ID - Static variable in class org.apache.pig.backend.hadoop.executionengine.spark.JobGraphBuilder
 
NullSchema - Static variable in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
 
nullTuple(ThreadContext, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a static helper method to create a null aliased tuple Schema.
numberOfEquivalenceClasses() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
numberOfEquivalenceClasses() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
numHash - Variable in class org.apache.pig.builtin.BuildBloomBase
 
numInputs - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
numPartitions() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.MapReducePartitionerWrapper
 
numQuantiles - Variable in class org.apache.pig.impl.builtin.FindQuantiles
 
NUMROWS_TUPLE_MARKER - Static variable in class org.apache.pig.impl.builtin.PoissonSampleLoader
 
numRowSplTupleReturned - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
numRowsSampled - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
numSamples - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POReservoirSample
 
numSamples - Variable in class org.apache.pig.impl.builtin.SampleLoader
 
numSkipped - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
numTypes() - Static method in class org.apache.pig.data.DataType
Return the number of types Pig knows about.
NumValCarrier - Class in org.apache.pig.impl.util
 
NumValCarrier() - Constructor for class org.apache.pig.impl.util.NumValCarrier
 

O

ObjectCache - Class in org.apache.pig.backend.hadoop.executionengine.tez.runtime
 
ObjectSerializer - Class in org.apache.pig.impl.util
 
ObjectSerializer() - Constructor for class org.apache.pig.impl.util.ObjectSerializer
 
objectToText(Object, ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
objToBytes(Object, byte) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
objToText(Object, byte) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
offset - Variable in class org.apache.pig.FileSplitComparable
 
offset() - Method in class org.apache.pig.parser.SourceLocation
 
offsetsToIndexKeys - Variable in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageOutputFormat
Offsets to index keys in given tuple
offsetsToIndexKeys - Variable in class org.apache.pig.piggybank.storage.IndexedStorage
Offsets to index keys in tuple
omittable - Variable in class org.apache.pig.pen.util.ExampleTuple
 
onApplicationEnd(SparkListenerApplicationEnd) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onApplicationStart(SparkListenerApplicationStart) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onBlockManagerAdded(SparkListenerBlockManagerAdded) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onBlockManagerRemoved(SparkListenerBlockManagerRemoved) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onBlockUpdated(SparkListenerBlockUpdated) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
ONE - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
onEnvironmentUpdate(SparkListenerEnvironmentUpdate) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onError(String, Exception, Tuple) - Method in class org.apache.pig.CounterBasedErrorHandler
 
onError(String, Exception, Tuple) - Method in interface org.apache.pig.ErrorHandler
Method invoked when an error occurs processing of tuple
onExecutorAdded(SparkListenerExecutorAdded) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onExecutorMetricsUpdate(SparkListenerExecutorMetricsUpdate) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onExecutorRemoved(SparkListenerExecutorRemoved) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onJobEnd(SparkListenerJobEnd) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onJobStart(SparkListenerJobStart) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onRootVertexInitialized(String, InputDescriptor, List<Event>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PartitionerDefinedVertexManager
 
onSourceTaskCompleted(String, Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PartitionerDefinedVertexManager
 
onStageCompleted(SparkListenerStageCompleted) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onStageSubmitted(SparkListenerStageSubmitted) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onSuccess(String) - Method in class org.apache.pig.CounterBasedErrorHandler
 
onSuccess(String) - Method in interface org.apache.pig.ErrorHandler
Method invoked on success processing of tuple
onTaskEnd(SparkListenerTaskEnd) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onTaskGettingResult(SparkListenerTaskGettingResult) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onTaskStart(SparkListenerTaskStart) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onUnpersistRDD(SparkListenerUnpersistRDD) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
onVertexManagerEventReceived(VertexManagerEvent) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PartitionerDefinedVertexManager
 
onVertexStarted(Map<String, List<Integer>>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PartitionerDefinedVertexManager
 
onVertexStateUpdated(VertexStateUpdate) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PartitionerDefinedVertexManager
 
onVertexStateUpdated(VertexStateUpdate) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigGraceShuffleVertexManager
 
open(Properties) - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
Open for read a given entity
open() - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
 
open(Properties) - Method in class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
open() - Method in class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
open(Properties) - Method in class org.apache.pig.backend.hadoop.datastorage.HFile
 
open() - Method in class org.apache.pig.backend.hadoop.datastorage.HFile
 
open() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
open(String, ExecType, DataStorage) - Static method in class org.apache.pig.impl.io.FileLocalizer
open(String, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
open(String, long, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
openDFSFile(String) - Static method in class org.apache.pig.impl.io.FileLocalizer
This function is meant to be used if the mappers/reducers want to access any HDFS file
openDFSFile(String, Properties) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
openIndexFile(FileSystem) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Opens the index file.
openIterator(String) - Method in class org.apache.pig.PigServer
Executes a Pig Latin script up to and including indicated alias.
operandType - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryComparisonOperator
 
operandType - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryComparisonOperator
 
Operator<V extends PlanVisitor> - Class in org.apache.pig.impl.plan
Base class for all types of operators.
Operator(OperatorKey) - Constructor for class org.apache.pig.impl.plan.Operator
 
Operator - Class in org.apache.pig.newplan
 
Operator(String, OperatorPlan) - Constructor for class org.apache.pig.newplan.Operator
 
OperatorKey - Class in org.apache.pig.impl.plan
 
OperatorKey() - Constructor for class org.apache.pig.impl.plan.OperatorKey
 
OperatorKey(String, long) - Constructor for class org.apache.pig.impl.plan.OperatorKey
 
OperatorPlan<E extends Operator> - Class in org.apache.pig.impl.plan
A generic graphing class for use by LogicalPlan, PhysicalPlan, etc.
OperatorPlan() - Constructor for class org.apache.pig.impl.plan.OperatorPlan
 
OperatorPlan - Interface in org.apache.pig.newplan
An interface that defines graph operations on plans.
OperatorPlan.IndexHelper<E> - Class in org.apache.pig.impl.plan
 
OperatorSubPlan - Class in org.apache.pig.newplan
Class to represent a view of a plan.
OperatorSubPlan(OperatorPlan) - Constructor for class org.apache.pig.newplan.OperatorSubPlan
 
ops - Variable in class org.apache.pig.newplan.BaseOperatorPlan
 
opsToBeReset - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
OPT_FETCH - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
use PigConfiguration.PIG_OPT_FETCH instead. Will be removed in Pig 0.16
OPTIMISTIC_FILE_CONCATENATION - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
OPTIMISTIC_FILE_CONCATENATION - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
optimize(PigContext) - Method in class org.apache.pig.newplan.logical.relational.LogicalPlan
 
optimize() - Method in class org.apache.pig.newplan.optimizer.PlanOptimizer
Run the optimizer.
OptimizeLimitTransformer() - Constructor for class org.apache.pig.newplan.logical.rules.LimitOptimizer.OptimizeLimitTransformer
 
OptimizeNestedLimitTransformer() - Constructor for class org.apache.pig.newplan.logical.rules.NestedLimitOptimizer.OptimizeNestedLimitTransformer
 
OptimizerException - Exception in org.apache.pig.impl.plan.optimizer
 
OptimizerException() - Constructor for exception org.apache.pig.impl.plan.optimizer.OptimizerException
Create a new OptimizerException with null as the error message.
OptimizerException(String) - Constructor for exception org.apache.pig.impl.plan.optimizer.OptimizerException
Create a new OptimizerException with the specified message and cause.
OptimizerException(Throwable) - Constructor for exception org.apache.pig.impl.plan.optimizer.OptimizerException
Create a new OptimizerException with the specified cause.
OptimizerException(String, Throwable) - Constructor for exception org.apache.pig.impl.plan.optimizer.OptimizerException
Create a new OptimizerException with the specified message and cause.
OptimizerException(String, int) - Constructor for exception org.apache.pig.impl.plan.optimizer.OptimizerException
Create a new OptimizerException with the specified message and cause.
OptimizerException(String, int, Throwable) - Constructor for exception org.apache.pig.impl.plan.optimizer.OptimizerException
Create a new OptimizerException with the specified message and cause.
OptimizerException(String, int, byte) - Constructor for exception org.apache.pig.impl.plan.optimizer.OptimizerException
Create a new OptimizerException with the specified message and cause.
OptimizerException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.impl.plan.optimizer.OptimizerException
Create a new OptimizerException with the specified message and cause.
OptimizerException(String, int, boolean) - Constructor for exception org.apache.pig.impl.plan.optimizer.OptimizerException
Create a new OptimizerException with the specified message and cause.
OptimizerException(String, int, byte, boolean) - Constructor for exception org.apache.pig.impl.plan.optimizer.OptimizerException
Create a new OptimizerException with the specified message and cause.
OptimizerException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.impl.plan.optimizer.OptimizerException
Create a new OptimizerException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
OptimizerException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.impl.plan.optimizer.OptimizerException
Create a new OptimizerException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
OptimizerUtils - Class in org.apache.pig.newplan.logical.rules
 
OptimizerUtils() - Constructor for class org.apache.pig.newplan.logical.rules.OptimizerUtils
 
OPTION_GROUPTYPE - Static variable in class org.apache.pig.newplan.logical.relational.LOCogroup
static constant to refer to the option of selecting a group type
OPTION_JOIN - Static variable in class org.apache.pig.newplan.logical.relational.LOJoin
static constant to refer to the option of selecting a join type
opType - Variable in class org.apache.pig.Expression
 
OrcStorage - Class in org.apache.pig.builtin
A load function and store function for ORC file.
OrcStorage() - Constructor for class org.apache.pig.builtin.OrcStorage
 
OrcStorage(String) - Constructor for class org.apache.pig.builtin.OrcStorage
 
OrcStorage.NonEmptyOrcFileFilter - Class in org.apache.pig.builtin
 
OrderedLoadFunc - Interface in org.apache.pig
Implementing this interface indicates to Pig that a given loader can be used for MergeJoin.
OrExpression - Class in org.apache.pig.newplan.logical.expression
Boolean OR Expression
OrExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.OrExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
org.apache.pig - package org.apache.pig
Public interfaces and classes for Pig.
org.apache.pig.backend - package org.apache.pig.backend
 
org.apache.pig.backend.datastorage - package org.apache.pig.backend.datastorage
 
org.apache.pig.backend.executionengine - package org.apache.pig.backend.executionengine
 
org.apache.pig.backend.hadoop - package org.apache.pig.backend.hadoop
 
org.apache.pig.backend.hadoop.accumulo - package org.apache.pig.backend.hadoop.accumulo
 
org.apache.pig.backend.hadoop.datastorage - package org.apache.pig.backend.hadoop.datastorage
 
org.apache.pig.backend.hadoop.executionengine - package org.apache.pig.backend.hadoop.executionengine
 
org.apache.pig.backend.hadoop.executionengine.fetch - package org.apache.pig.backend.hadoop.executionengine.fetch
 
org.apache.pig.backend.hadoop.executionengine.mapReduceLayer - package org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners - package org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners
 
org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans - package org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
 
org.apache.pig.backend.hadoop.executionengine.optimizer - package org.apache.pig.backend.hadoop.executionengine.optimizer
 
org.apache.pig.backend.hadoop.executionengine.physicalLayer - package org.apache.pig.backend.hadoop.executionengine.physicalLayer
Implementation of physical operators that use hadoop as the execution engine and data storage.
org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators - package org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex - package org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex
 
org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans - package org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans
 
org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators - package org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
org.apache.pig.backend.hadoop.executionengine.physicalLayer.util - package org.apache.pig.backend.hadoop.executionengine.physicalLayer.util
 
org.apache.pig.backend.hadoop.executionengine.spark - package org.apache.pig.backend.hadoop.executionengine.spark
 
org.apache.pig.backend.hadoop.executionengine.spark.converter - package org.apache.pig.backend.hadoop.executionengine.spark.converter
 
org.apache.pig.backend.hadoop.executionengine.spark.operator - package org.apache.pig.backend.hadoop.executionengine.spark.operator
 
org.apache.pig.backend.hadoop.executionengine.spark.optimizer - package org.apache.pig.backend.hadoop.executionengine.spark.optimizer
 
org.apache.pig.backend.hadoop.executionengine.spark.plan - package org.apache.pig.backend.hadoop.executionengine.spark.plan
 
org.apache.pig.backend.hadoop.executionengine.spark.running - package org.apache.pig.backend.hadoop.executionengine.spark.running
 
org.apache.pig.backend.hadoop.executionengine.spark.streaming - package org.apache.pig.backend.hadoop.executionengine.spark.streaming
 
org.apache.pig.backend.hadoop.executionengine.tez - package org.apache.pig.backend.hadoop.executionengine.tez
 
org.apache.pig.backend.hadoop.executionengine.tez.plan - package org.apache.pig.backend.hadoop.executionengine.tez.plan
 
org.apache.pig.backend.hadoop.executionengine.tez.plan.operator - package org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
 
org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer - package org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
 
org.apache.pig.backend.hadoop.executionengine.tez.plan.udf - package org.apache.pig.backend.hadoop.executionengine.tez.plan.udf
 
org.apache.pig.backend.hadoop.executionengine.tez.runtime - package org.apache.pig.backend.hadoop.executionengine.tez.runtime
 
org.apache.pig.backend.hadoop.executionengine.tez.util - package org.apache.pig.backend.hadoop.executionengine.tez.util
 
org.apache.pig.backend.hadoop.executionengine.util - package org.apache.pig.backend.hadoop.executionengine.util
 
org.apache.pig.backend.hadoop.hbase - package org.apache.pig.backend.hadoop.hbase
 
org.apache.pig.backend.hadoop.streaming - package org.apache.pig.backend.hadoop.streaming
 
org.apache.pig.builtin - package org.apache.pig.builtin
This package contains builtin Pig UDFs.
org.apache.pig.builtin.mock - package org.apache.pig.builtin.mock
 
org.apache.pig.classification - package org.apache.pig.classification
 
org.apache.pig.data - package org.apache.pig.data
This package contains implementations of Pig specific data types as well as support functions for reading, writing, and using all Pig data types.
org.apache.pig.data.utils - package org.apache.pig.data.utils
 
org.apache.pig.impl - package org.apache.pig.impl
 
org.apache.pig.impl.builtin - package org.apache.pig.impl.builtin
 
org.apache.pig.impl.io - package org.apache.pig.impl.io
 
org.apache.pig.impl.io.compress - package org.apache.pig.impl.io.compress
 
org.apache.pig.impl.logicalLayer - package org.apache.pig.impl.logicalLayer
The logical operators that represent a pig script and tools for manipulating those operators.
org.apache.pig.impl.logicalLayer.schema - package org.apache.pig.impl.logicalLayer.schema
 
org.apache.pig.impl.logicalLayer.validators - package org.apache.pig.impl.logicalLayer.validators
 
org.apache.pig.impl.plan - package org.apache.pig.impl.plan
 
org.apache.pig.impl.plan.optimizer - package org.apache.pig.impl.plan.optimizer
 
org.apache.pig.impl.streaming - package org.apache.pig.impl.streaming
 
org.apache.pig.impl.util - package org.apache.pig.impl.util
 
org.apache.pig.impl.util.avro - package org.apache.pig.impl.util.avro
 
org.apache.pig.impl.util.hive - package org.apache.pig.impl.util.hive
 
org.apache.pig.newplan - package org.apache.pig.newplan
 
org.apache.pig.newplan.logical - package org.apache.pig.newplan.logical
 
org.apache.pig.newplan.logical.expression - package org.apache.pig.newplan.logical.expression
 
org.apache.pig.newplan.logical.optimizer - package org.apache.pig.newplan.logical.optimizer
 
org.apache.pig.newplan.logical.relational - package org.apache.pig.newplan.logical.relational
 
org.apache.pig.newplan.logical.rules - package org.apache.pig.newplan.logical.rules
 
org.apache.pig.newplan.logical.visitor - package org.apache.pig.newplan.logical.visitor
 
org.apache.pig.newplan.optimizer - package org.apache.pig.newplan.optimizer
 
org.apache.pig.parser - package org.apache.pig.parser
 
org.apache.pig.pen - package org.apache.pig.pen
 
org.apache.pig.pen.util - package org.apache.pig.pen.util
 
org.apache.pig.piggybank.evaluation - package org.apache.pig.piggybank.evaluation
 
org.apache.pig.piggybank.evaluation.datetime - package org.apache.pig.piggybank.evaluation.datetime
 
org.apache.pig.piggybank.evaluation.datetime.convert - package org.apache.pig.piggybank.evaluation.datetime.convert
 
org.apache.pig.piggybank.evaluation.datetime.diff - package org.apache.pig.piggybank.evaluation.datetime.diff
 
org.apache.pig.piggybank.evaluation.datetime.truncate - package org.apache.pig.piggybank.evaluation.datetime.truncate
 
org.apache.pig.piggybank.evaluation.decode - package org.apache.pig.piggybank.evaluation.decode
 
org.apache.pig.piggybank.evaluation.math - package org.apache.pig.piggybank.evaluation.math
 
org.apache.pig.piggybank.evaluation.stats - package org.apache.pig.piggybank.evaluation.stats
 
org.apache.pig.piggybank.evaluation.string - package org.apache.pig.piggybank.evaluation.string
 
org.apache.pig.piggybank.evaluation.util - package org.apache.pig.piggybank.evaluation.util
 
org.apache.pig.piggybank.evaluation.util.apachelogparser - package org.apache.pig.piggybank.evaluation.util.apachelogparser
 
org.apache.pig.piggybank.evaluation.xml - package org.apache.pig.piggybank.evaluation.xml
 
org.apache.pig.piggybank.storage - package org.apache.pig.piggybank.storage
 
org.apache.pig.piggybank.storage.allloader - package org.apache.pig.piggybank.storage.allloader
 
org.apache.pig.piggybank.storage.apachelog - package org.apache.pig.piggybank.storage.apachelog
 
org.apache.pig.piggybank.storage.avro - package org.apache.pig.piggybank.storage.avro
 
org.apache.pig.piggybank.storage.hiverc - package org.apache.pig.piggybank.storage.hiverc
 
org.apache.pig.piggybank.storage.partition - package org.apache.pig.piggybank.storage.partition
 
org.apache.pig.scripting - package org.apache.pig.scripting
 
org.apache.pig.scripting.groovy - package org.apache.pig.scripting.groovy
 
org.apache.pig.scripting.jruby - package org.apache.pig.scripting.jruby
 
org.apache.pig.scripting.js - package org.apache.pig.scripting.js
 
org.apache.pig.scripting.jython - package org.apache.pig.scripting.jython
 
org.apache.pig.scripting.streaming.python - package org.apache.pig.scripting.streaming.python
 
org.apache.pig.tools - package org.apache.pig.tools
 
org.apache.pig.tools.cmdline - package org.apache.pig.tools.cmdline
 
org.apache.pig.tools.counters - package org.apache.pig.tools.counters
 
org.apache.pig.tools.grunt - package org.apache.pig.tools.grunt
 
org.apache.pig.tools.parameters - package org.apache.pig.tools.parameters
 
org.apache.pig.tools.pigstats - package org.apache.pig.tools.pigstats
 
org.apache.pig.tools.pigstats.mapreduce - package org.apache.pig.tools.pigstats.mapreduce
 
org.apache.pig.tools.pigstats.spark - package org.apache.pig.tools.pigstats.spark
 
org.apache.pig.tools.pigstats.tez - package org.apache.pig.tools.pigstats.tez
 
org.apache.pig.tools.streams - package org.apache.pig.tools.streams
 
org.apache.pig.tools.timer - package org.apache.pig.tools.timer
 
org.apache.pig.validator - package org.apache.pig.validator
 
OriginalLocation(String, int, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator.OriginalLocation
 
originalPlan - Variable in class org.apache.pig.newplan.FilterExtractor
We visit this plan to create the filteredPlan
outEdges - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
outerrThreadsError - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
outFileSpec - Variable in class org.apache.pig.backend.hadoop.executionengine.HJob
 
outFileSpec - Variable in class org.apache.pig.backend.hadoop.executionengine.MapRedResult
 
OUTPUT_AVRO_SCHEMA - Static variable in class org.apache.pig.builtin.AvroStorage
Pig property name for the output avro schema.
OUTPUT_BASENAME - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
OUTPUT_CODEC - Static variable in class org.apache.pig.piggybank.storage.avro.PigAvroOutputFormat
The configuration key for the Avro codec.
OUTPUT_COMPRESS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
OUTPUT_COMPRESSION_CODEC - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
OUTPUT_DIR - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
OUTPUT_SIZE_READER_KEY - Static variable in interface org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigStatsOutputSizeReader
 
OUTPUT_SIZE_READER_UNSUPPORTED - Static variable in interface org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigStatsOutputSizeReader
 
outputBytes - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
outputClassName - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
outputCollector - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
 
outputCompletedNotification(String, OutputStats) - Method in interface org.apache.pig.tools.pigstats.PigProgressNotificationListener
Invoked just after an output is successfully written.
OutputHandler - Class in org.apache.pig.impl.streaming
OutputHandler is responsible for handling the output of the Pig-Streaming external command.
OutputHandler() - Constructor for class org.apache.pig.impl.streaming.OutputHandler
 
OutputHandler.OutputType - Enum in org.apache.pig.impl.streaming
 
outputKey - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
outputRecords - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
outputs - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
outputs - Variable in class org.apache.pig.tools.pigstats.JobStats
 
outputSchema(Schema) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.ABS
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.AddDuration
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.AlgebraicBigDecimalMathBase
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.AlgebraicBigIntegerMathBase
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.AlgebraicByteArrayMathBase
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.AlgebraicDoubleMathBase
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.AlgebraicFloatMathBase
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.AlgebraicIntMathBase
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.AlgebraicLongMathBase
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.ARITY
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.AVG
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.BagSize
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.BagToString
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.BagToTuple
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.Base
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.BigDecimalAvg
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.BigIntegerAvg
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.BuildBloom
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.CONCAT
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.ConstantSize
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.COR
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.COUNT
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.COUNT_STAR
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.COV
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.CubeDimensions
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.DateTimeMax
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.DateTimeMin
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.DaysBetween
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.DoubleAvg
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.DoubleRound
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.ENDSWITH
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.FloatAbs
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.FloatAvg
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.FloatRound
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.GenericInvoker
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.GetDay
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.GetHour
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.GetMilliSecond
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.GetMinute
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.GetMonth
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.GetSecond
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.GetWeek
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.GetWeekYear
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.GetYear
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.HiveUDAF
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.HiveUDF
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.HiveUDTF
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.HoursBetween
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.INDEXOF
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.IntAbs
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.IntAvg
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.INVERSEMAP
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.InvokerGenerator
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.KEYSET
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.LAST_INDEX_OF
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.LCFIRST
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.LongAbs
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.LongAvg
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.LOWER
This method gives a name to the column.
outputSchema(Schema) - Method in class org.apache.pig.builtin.LTRIM
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.MapSize
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.MilliSecondsBetween
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.MinutesBetween
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.MonthsBetween
 
OutputSchema - Annotation Type in org.apache.pig.builtin
An EvalFunc can annotated with an OutputSchema to tell Pig what the expected output is.
outputSchema(Schema) - Method in class org.apache.pig.builtin.PluckTuple
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.RANDOM
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.REGEX_EXTRACT
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.REGEX_EXTRACT_ALL
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.REGEX_SEARCH
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.REPLACE
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.RollupDimensions
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.ROUND
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.ROUND_TO
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.RTRIM
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.SecondsBetween
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.SIZE
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.SPRINTF
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.STARTSWITH
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.StringConcat
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.StringMax
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.StringMin
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.StringSize
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.STRSPLIT
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.STRSPLITTOBAG
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.SUBSTRING
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.SubtractDuration
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.TOBAG
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.ToDate
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.TOKENIZE
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.TOMAP
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.ToMilliSeconds
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.TOP
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.ToString
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.TOTUPLE
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.ToUnixTime
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.TRIM
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.TupleSize
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.UCFIRST
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.UniqueID
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.UPPER
This method gives a name to the column.
outputSchema(Schema) - Method in class org.apache.pig.builtin.VALUELIST
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.VALUESET
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.WeeksBetween
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.YearsBetween
 
outputSchema(Schema) - Method in class org.apache.pig.EvalFunc
Report the schema of the output of this UDF.
outputSchema(Schema) - Method in class org.apache.pig.impl.builtin.IdentityColumn
 
outputSchema(Schema) - Method in class org.apache.pig.impl.builtin.StreamingUDF
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.convert.CustomFormatToISO
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.convert.ISOToUnix
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.convert.UnixToISO
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISODaysBetween
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOHoursBetween
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOMinutesBetween
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOMonthsBetween
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOSecondsBetween
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.diff.ISOYearsBetween
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.DiffDate
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToDay
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToHour
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToMinute
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToMonth
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToSecond
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToWeek
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOToYear
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.decode.Bin
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.decode.BinCond
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.decode.Decode
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.IsDouble
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.IsFloat
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.IsInt
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.IsLong
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.IsNumeric
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.ABS
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.Base
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.copySign
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleAbs
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleCopySign
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleGetExponent
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleMax
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleMin
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleNextAfter
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleNextup
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleRound
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleSignum
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.DoubleUlp
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.FloatAbs
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.FloatCopySign
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.FloatGetExponent
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.FloatMax
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.FloatMin
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.FloatNextAfter
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.FloatNextup
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.FloatRound
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.FloatSignum
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.FloatUlp
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.getExponent
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.IntAbs
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.IntMax
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.IntMin
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.LongAbs
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.LongMax
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.LongMin
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.MAX
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.MIN
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.nextAfter
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.NEXTUP
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.ROUND
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.SCALB
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.SIGNUM
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.math.ULP
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.MaxTupleBy1stField
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.Over
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.stats.COR
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.stats.COV
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.Stitch
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.string.HashFNV
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.string.LENGTH
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.string.LookupInFiles
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.string.RegexExtract
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.string.RegexExtractAll
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.string.RegexMatch
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.string.REPLACE_MULTI
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.string.Reverse
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.string.Stuff
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.string.UPPER
Deprecated.
This method gives a name to the column.
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.util.SearchQuery
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.util.Top
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.piggybank.evaluation.util.ToTuple
Deprecated.
 
outputSchema(Schema) - Method in class org.apache.pig.scripting.groovy.GroovyAccumulatorEvalFunc
 
outputSchema(Schema) - Method in class org.apache.pig.scripting.groovy.GroovyEvalFunc
 
outputSchema(Schema) - Method in class org.apache.pig.scripting.jruby.JrubyAccumulatorEvalFunc
This provides the Schema of the output, and leverages the get_output_schema function on the class object that is defined on the ruby side.
outputSchema(Schema) - Method in class org.apache.pig.scripting.jruby.JrubyEvalFunc
This method uses the schema method of the function encapsulation object to get the Schema information for the Ruby method.
outputSchema(Schema) - Method in class org.apache.pig.scripting.js.JsFunction
 
outputSchema(Schema) - Method in class org.apache.pig.scripting.jython.JythonFunction
 
OutputSchemaFunction - Annotation Type in org.apache.pig.scripting.groovy
 
OutputStats - Class in org.apache.pig.tools.pigstats
This class encapsulates the runtime statistics of an user specified output.
OutputStats(String, long, long, boolean) - Constructor for class org.apache.pig.tools.pigstats.OutputStats
 
OUTPUTUIDS - Static variable in class org.apache.pig.newplan.logical.rules.ColumnPruneHelper
 
outTypeClass - Variable in class org.apache.pig.TypedOutputEvalFunc
 
Over - Class in org.apache.pig.piggybank.evaluation
Given an aggregate function, a bag, and possibly a window definition, produce output that matches SQL OVER.
Over() - Constructor for class org.apache.pig.piggybank.evaluation.Over
 
Over(String) - Constructor for class org.apache.pig.piggybank.evaluation.Over
 
overloaded - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
OverwritableStoreFunc - Interface in org.apache.pig
A StoreFunc should implement this interface to enable overwriting its store/output location if it already exists.
OWNER_ONLY_PERMS - Static variable in class org.apache.pig.impl.io.FileLocalizer
 

P

pack - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
 
pack - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl
 
PackageConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
PackageConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.PackageConverter
 
Packager - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
Packager() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
Packager.PackageType - Enum in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
packIntoAvro(Tuple, Schema) - Static method in class org.apache.pig.impl.util.avro.AvroStorageDataConversionUtilities
Packs a Pig Tuple into an Avro record.
packIntoAvro(DataBag, Schema) - Static method in class org.apache.pig.impl.util.avro.AvroStorageDataConversionUtilities
Packs a Pig DataBag into an Avro array.
Pair(T1, T2) - Constructor for class org.apache.pig.data.utils.StructuresHelper.Pair
 
Pair<T,U> - Class in org.apache.pig.impl.util
Copy of C++ STL pair container.
Pair(T, U) - Constructor for class org.apache.pig.impl.util.Pair
 
ParallelConstantVisitor - Class in org.apache.pig.backend.hadoop.executionengine.util
 
ParallelConstantVisitor(PhysicalPlan, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.util.ParallelConstantVisitor
 
parallelismRequest - Variable in class org.apache.pig.backend.hadoop.executionengine.MapRedResult
 
ParallelismSetter - Class in org.apache.pig.backend.hadoop.executionengine.spark.optimizer
 
ParallelismSetter(SparkOperPlan, JobConf) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.ParallelismSetter
 
ParallelismSetter - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
 
ParallelismSetter(TezOperPlan, PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.ParallelismSetter
 
ParameterSubstitutionException - Exception in org.apache.pig.tools.parameters
 
ParameterSubstitutionException(String) - Constructor for exception org.apache.pig.tools.parameters.ParameterSubstitutionException
 
ParameterSubstitutionPreprocessor - Class in org.apache.pig.tools.parameters
 
ParameterSubstitutionPreprocessor(int) - Constructor for class org.apache.pig.tools.parameters.ParameterSubstitutionPreprocessor
 
ParameterSubstitutionPreprocessor(PreprocessorContext) - Constructor for class org.apache.pig.tools.parameters.ParameterSubstitutionPreprocessor
 
paramMapToList(Map<String, String>) - Method in class org.apache.pig.PigServer
 
paramScopePop() - Method in class org.apache.pig.tools.parameters.PreprocessorContext
 
paramScopePush() - Method in class org.apache.pig.tools.parameters.PreprocessorContext
 
paramval_containsKey(String) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
 
paramval_get(String) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
 
paramval_put(String, String) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
 
parent - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
parentPlan - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
PARITITION_FILTER_EXPRESSION - Static variable in class org.apache.pig.piggybank.storage.partition.PathPartitionHelper
 
ParquetLoader - Class in org.apache.pig.builtin
Wrapper class which will delegate calls to parquet.pig.ParquetLoader
ParquetLoader() - Constructor for class org.apache.pig.builtin.ParquetLoader
 
ParquetLoader(String) - Constructor for class org.apache.pig.builtin.ParquetLoader
 
ParquetStorer - Class in org.apache.pig.builtin
Wrapper class which will delegate calls to parquet.pig.ParquetStorer
ParquetStorer() - Constructor for class org.apache.pig.builtin.ParquetStorer
 
parse(String) - Method in class org.apache.pig.parser.QueryParserDriver
 
PARSE_EXCEPTION - Static variable in class org.apache.pig.PigRunner.ReturnCode
 
parseAndBuild() - Method in class org.apache.pig.PigServer
This method parses the scripts and builds the LogicalPlan.
parseArguments(String) - Static method in class org.apache.pig.FuncSpec
Parse the argument values out of a function specification string.
parseColumnSpec(String) - Static method in class org.apache.pig.piggybank.storage.FixedWidthLoader
 
parseConstant(String) - Static method in class org.apache.pig.impl.util.Utils
 
parseConstant(String) - Method in class org.apache.pig.parser.QueryParserDriver
 
parseCygPath(String, int) - Static method in class org.apache.pig.impl.io.FileLocalizer
Convert path from Windows convention to Unix convention.
parseDateTime(Tuple) - Static method in class org.apache.pig.piggybank.evaluation.datetime.truncate.ISOHelper
 
parseFieldDel(String) - Static method in class org.apache.pig.impl.util.StorageUtil
Transform a String into a byte representing the field delimiter.
parseFieldIndex(String) - Static method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
 
parseJsonString(String) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
build a property map from a json object
parseLazyArrayToPigArray(LazyArray) - Static method in class org.apache.pig.piggybank.storage.hiverc.HiveRCSchemaUtil
Converts the LazyArray to a Tuple.
parseLazyMapToPigMap(LazyMap) - Static method in class org.apache.pig.piggybank.storage.hiverc.HiveRCSchemaUtil
Converts the LazyMap to a InternalMap.
parseOnly() - Method in class org.apache.pig.tools.grunt.GruntParser
 
parseOrdering(String) - Static method in class org.apache.pig.piggybank.evaluation.ExtremalTupleByNthField
 
parsePathKeyValue(String) - Method in class org.apache.pig.piggybank.storage.partition.PathPartitioner
Will look for key=value pairs in the path for example: /user/hive/warehouse/mylogs/year=2010/month=07
parseRegister(String, String, String) - Method in class org.apache.pig.parser.RegisterResolver
 
ParserException - Exception in org.apache.pig.parser
 
ParserException(RecognitionException) - Constructor for exception org.apache.pig.parser.ParserException
 
ParserException(String) - Constructor for exception org.apache.pig.parser.ParserException
 
ParserException(String, SourceLocation) - Constructor for exception org.apache.pig.parser.ParserException
 
ParserException(String, Throwable) - Constructor for exception org.apache.pig.parser.ParserException
 
ParserValidationException - Exception in org.apache.pig.parser
 
ParserValidationException(IntStream, SourceLocation, String) - Constructor for exception org.apache.pig.parser.ParserValidationException
 
ParserValidationException(IntStream, SourceLocation, Exception) - Constructor for exception org.apache.pig.parser.ParserValidationException
 
parseSchema(String) - Static method in class org.apache.pig.impl.util.Utils
 
parseSchema(String) - Method in class org.apache.pig.parser.QueryParserDriver
 
parseSchema(Pattern, String) - Static method in class org.apache.pig.piggybank.storage.hiverc.HiveRCSchemaUtil
General schema parsing method, is used to parse the column names.
parseSchemaTypes(String) - Static method in class org.apache.pig.piggybank.storage.hiverc.HiveRCSchemaUtil
Parses the schema types and returns a List of these.
parseStopOnError() - Method in class org.apache.pig.parser.DryRunGruntParser
 
parseStopOnError() - Method in class org.apache.pig.tools.grunt.GruntParser
 
parseStopOnError(boolean) - Method in class org.apache.pig.tools.grunt.GruntParser
Parses Pig commands in either interactive mode or batch mode.
parseStringList(String[]) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
build a property map from a string list
PARTAGG_MINREDUCTION - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
use PigConfiguration.PIG_EXEC_MAP_PARTAGG_MINREDUCTION instead. Will be removed in Pig 0.16
PARTIAL_FAILURE - Static variable in class org.apache.pig.PigRunner.ReturnCode
 
PARTITION_COLUMNS - Static variable in class org.apache.pig.piggybank.storage.partition.PathPartitionHelper
 
PARTITION_LIST - Static variable in class org.apache.pig.impl.builtin.PartitionSkewedKeys
 
partitionerClass - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
PartitionerDefinedVertexManager - Class in org.apache.pig.backend.hadoop.executionengine.tez.runtime
VertexManagerPlugin used by sorting job of order by and skewed join.
PartitionerDefinedVertexManager(VertexManagerPluginContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PartitionerDefinedVertexManager
 
PartitionFilterExtractor - Class in org.apache.pig.newplan
This is a rewrite of PColFilterExtractor Extracts partition filters for interfaces implementing LoadMetaData
PartitionFilterExtractor(LogicalExpressionPlan, List<String>) - Constructor for class org.apache.pig.newplan.PartitionFilterExtractor
 
PartitionFilterOptimizer - Class in org.apache.pig.newplan.logical.rules
 
PartitionFilterOptimizer(String) - Constructor for class org.apache.pig.newplan.logical.rules.PartitionFilterOptimizer
 
PartitionFilterOptimizer.PartitionFilterPushDownTransformer - Class in org.apache.pig.newplan.logical.rules
 
PartitionFilterPushDownTransformer() - Constructor for class org.apache.pig.newplan.logical.rules.PartitionFilterOptimizer.PartitionFilterPushDownTransformer
 
PartitionSkewedKeys - Class in org.apache.pig.impl.builtin
Partition reducers for skewed keys.
PartitionSkewedKeys() - Constructor for class org.apache.pig.impl.builtin.PartitionSkewedKeys
 
PartitionSkewedKeys(String[]) - Constructor for class org.apache.pig.impl.builtin.PartitionSkewedKeys
 
PartitionSkewedKeysTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.udf
 
PartitionSkewedKeysTez() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.PartitionSkewedKeysTez
 
PartitionSkewedKeysTez(String[]) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.PartitionSkewedKeysTez
 
password - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
path - Variable in class org.apache.pig.backend.hadoop.datastorage.HPath
 
PATH_FILTER - Static variable in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
ignore hdfs files with prefix "_" and "."
pathExists(E, E) - Method in class org.apache.pig.impl.plan.OperatorPlan
A method to check if there is a path from a given node to another node
pathExists(Operator, Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
A method to check if there is a path from a given node to another node
pathExists(Operator, Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
check if there is a path in the plan graph between the load operator to the store operator.
pathExists(Operator, Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
PathPartitioner - Class in org.apache.pig.piggybank.storage.partition
Its convenient sometimes to partition logs by date values or other e.g.
PathPartitioner() - Constructor for class org.apache.pig.piggybank.storage.partition.PathPartitioner
 
PathPartitionHelper - Class in org.apache.pig.piggybank.storage.partition
Implements the logic for:
Listing partition keys and values used in an hdfs path Filtering of partitions from a pig filter operator expression

Restrictions
Function calls are not supported by this partition helper and it can only handle String values.
This is normally not a problem given that partition values are part of the hdfs folder path and is given a
determined value that would not need parsing by any external processes.

PathPartitionHelper() - Constructor for class org.apache.pig.piggybank.storage.partition.PathPartitionHelper
 
pattern - Variable in class org.apache.pig.newplan.optimizer.Rule
 
PatternNode - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans
Used for finding/representing a pattern in the plan This class represents a node in the pattern
PatternNode(OperatorPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternNode
 
PatternPlan - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans
Used for finding/representing a pattern in the plan This class represents the pattern Finds only a single matching pattern This is finding a sub-graph( represented by pattern) in the graph(plan)
PatternPlan() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternPlan
 
pc - Variable in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
pc - Variable in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
pcols - Static variable in class org.apache.pig.piggybank.storage.HiveColumnarLoader
Regex to filter out column names
peekArray(Object) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumReader
Called by the default implementation of GenericDatumReader.readArray(java.lang.Object, org.apache.avro.Schema, org.apache.avro.io.ResolvingDecoder) to retrieve a value from a reused instance.
PerformanceTimer - Class in org.apache.pig.tools.timer
 
PerformanceTimerFactory - Class in org.apache.pig.tools.timer
 
phyPlanLists - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
PhyPlanSetter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Sets the parent plan for all Physical Operators.
PhyPlanSetter(PhysicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
PhyPlanVisitor - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans
The visitor class for the Physical Plan.
PhyPlanVisitor(PhysicalPlan, PlanWalker<PhysicalOperator, PhysicalPlan>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
PhysicalOperator - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer
This is the base class for all operators.
PhysicalOperator(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
PhysicalOperator(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
PhysicalOperator(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
PhysicalOperator(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
PhysicalOperator(PhysicalOperator) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
PhysicalOperator.OriginalLocation - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer
 
PhysicalPlan - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans
The base class for all types of physical plans.
PhysicalPlan() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
physicalPlan - Variable in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
PhysicalPlanResetter - Class in org.apache.pig.pen
This visitor visits the physical plan and resets it for next MRCompilation
PhysicalPlanResetter(PhysicalPlan) - Constructor for class org.apache.pig.pen.PhysicalPlanResetter
 
phyToMRMap - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
Pig - Class in org.apache.pig.scripting
The class being used in scripts to interact with Pig
Pig(String, ScriptPigContext, String) - Constructor for class org.apache.pig.scripting.Pig
 
PIG_ACCUMULATIVE_BATCHSIZE - Static variable in class org.apache.pig.PigConfiguration
 
PIG_ARTIFACTS_DOWNLOAD_LOCATION - Static variable in class org.apache.pig.PigConfiguration
This key is used to set the download location when registering an artifact using ivy coordinate
PIG_ATS_ENABLED - Static variable in class org.apache.pig.PigConfiguration
Enable ATS for Pig
PIG_AUDIT_ID - Static variable in class org.apache.pig.impl.PigImplConstants
A unique id for a Pig session used as callerId for underlining component
PIG_AUTO_LOCAL_ENABLED - Static variable in class org.apache.pig.PigConfiguration
This key is to turn on auto local mode feature
PIG_AUTO_LOCAL_INPUT_MAXBYTES - Static variable in class org.apache.pig.PigConfiguration
Controls the max threshold size to convert jobs to run in local mode
PIG_BLACKLIST - Static variable in class org.apache.pig.PigConfiguration
Comma-delimited entries of commands/operators that must be disallowed.
PIG_BLOOMJOIN_HASH_FUNCTIONS - Static variable in class org.apache.pig.PigConfiguration
The number of hash functions to be used in bloom computation.
PIG_BLOOMJOIN_HASH_TYPE - Static variable in class org.apache.pig.PigConfiguration
The type of hash function to use.
PIG_BLOOMJOIN_NUM_FILTERS - Static variable in class org.apache.pig.PigConfiguration
The number of bloom filters that will be created.
PIG_BLOOMJOIN_STRATEGY - Static variable in class org.apache.pig.PigConfiguration
Bloom join has two different kind of implementations.
PIG_BLOOMJOIN_VECTORSIZE_BYTES - Static variable in class org.apache.pig.PigConfiguration
The size in bytes of the bit vector to be used for the bloom filter.
PIG_BZIP_USE_HADOOP_INPUTFORMAT - Static variable in class org.apache.pig.PigConfiguration
Using hadoop's TextInputFormat for reading bzip input instead of using Pig's Bzip2TextInputFormat.
PIG_CACHEDBAG_DISTINCT_TYPE - Static variable in class org.apache.pig.PigConfiguration
 
PIG_CACHEDBAG_MEMUSAGE - Static variable in class org.apache.pig.PigConfiguration
Controls the fraction of total memory that is allowed to be used by cached bags.
PIG_CACHEDBAG_SORT_TYPE - Static variable in class org.apache.pig.PigConfiguration
 
PIG_CACHEDBAG_TYPE - Static variable in class org.apache.pig.PigConfiguration
Configurations for specifying alternate implementations for cached bags.
PIG_CMD_ARGS_REMAINDERS - Static variable in class org.apache.pig.impl.PigContext
 
PIG_COMPRESS_INPUT_SPLITS - Static variable in class org.apache.pig.PigConfiguration
This key is used to configure compression for the pig input splits which are not FileSplit.
PIG_COMPRESS_INPUT_SPLITS_DEFAULT - Static variable in class org.apache.pig.PigConfiguration
 
PIG_CONTEXT - Static variable in class org.apache.pig.impl.PigImplConstants
Pig context
PIG_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
PIG_CROSS_PARALLELISM - Static variable in class org.apache.pig.impl.PigImplConstants
Parallelism to be used for CROSS operation by GFCross UDF
PIG_DATETIME_DEFAULT_TIMEZONE - Static variable in class org.apache.pig.PigConfiguration
The timezone to be used by Pig datetime datatype
PIG_DATETIME_ZONES_LIST - Static variable in class org.apache.pig.impl.PigImplConstants
Used to carry zone ID list from frontend to backend (generated by frontend during Job creation)
PIG_DEFAULT_LOAD_FUNC - Static variable in class org.apache.pig.PigConfiguration
This key is used to define the default load func.
PIG_DEFAULT_STORE_FUNC - Static variable in class org.apache.pig.PigConfiguration
This key is used to define the default store func.
PIG_DELETE_TEMP_FILE - Static variable in class org.apache.pig.PigConfiguration
This key is used to define whether to delete intermediate files of Hadoop jobs.
PIG_ENABLE_TEMP_FILE_COMPRESSION - Static variable in class org.apache.pig.PigConfiguration
This key is used to define whether to have intermediate file compressed
PIG_ERROR_HANDLING_ENABLED - Static variable in class org.apache.pig.PigConfiguration
Boolean value used to enable or disable error handling for storers
PIG_ERROR_HANDLING_MIN_ERROR_RECORDS - Static variable in class org.apache.pig.PigConfiguration
Controls the minimum number of errors
PIG_ERROR_HANDLING_THRESHOLD_PERCENT - Static variable in class org.apache.pig.PigConfiguration
Set the threshold for percentage of errors
PIG_EXCEPTION - Static variable in class org.apache.pig.PigRunner.ReturnCode
 
PIG_EXEC_MAP_PARTAGG - Static variable in class org.apache.pig.PigConfiguration
Boolean value to enable or disable partial aggregation in map.
PIG_EXEC_MAP_PARTAGG_MINREDUCTION - Static variable in class org.apache.pig.PigConfiguration
Controls the minimum reduction in-mapper Partial Aggregation should achieve in order to stay on.
PIG_EXEC_NO_COMBINER - Static variable in class org.apache.pig.PigConfiguration
Boolean value to enable or disable use of combiners in MapReduce jobs.
PIG_EXEC_NO_COMBINER_REDUCER - Static variable in class org.apache.pig.PigConfiguration
Enable or disable use of combiners in reducer shuffle-merge phase in Tez.
PIG_EXEC_NO_SECONDARY_KEY - Static variable in class org.apache.pig.PigConfiguration
This key controls whether secondary sort key is used for optimization in case of nested distinct or sort
PIG_EXEC_REDUCER_ESTIMATOR - Static variable in class org.apache.pig.PigConfiguration
 
PIG_EXEC_REDUCER_ESTIMATOR_CONSTRUCTOR_ARG_KEY - Static variable in class org.apache.pig.PigConfiguration
 
PIG_EXECTYPE_MODE_LOCAL - Static variable in class org.apache.pig.impl.PigImplConstants
Used by pig to indicate that current job is running in local mode (local/tez_local) ie.
PIG_INPUT_LIMITS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
PIG_INPUT_SIGNATURES - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
PIG_INPUT_TARGETS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
PIG_INPUTS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
PIG_JOIN_REPLICATED_MAX_BYTES - Static variable in class org.apache.pig.PigConfiguration
This key used to control the maximum size loaded into the distributed cache when doing fragment-replicated join
PIG_LOCAL_CONF_PREFIX - Static variable in class org.apache.pig.PigConstants
Prefix used by pig to configure local mode configuration
PIG_LOG4J_PROPERTIES - Static variable in class org.apache.pig.impl.PigImplConstants
Pig log4j properties
PIG_LOG_TRACE_ID - Static variable in class org.apache.pig.PigConfiguration
Log tracing id that can be used by upstream clients for tracking respective logs
PIG_MAP_COUNTER - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
PIG_MAP_RANK_NAME - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
PIG_MAP_SEPARATOR - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
PIG_MAP_STORES - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
We will serialize the POStore(s) present in map and reduce in lists in the Hadoop Conf.
PIG_MAPRED_OUTPUT_DIR - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
the temporary directory for the multi store
PIG_MAX_COMBINED_SPLIT_SIZE - Static variable in class org.apache.pig.PigConfiguration
Specifies the size, in bytes, of data to be processed by a single map.
PIG_NO_SPLIT_COMBINATION - Static variable in class org.apache.pig.PigConfiguration
Whether turns combine split files off.
PIG_NO_TASK_REPORT - Static variable in class org.apache.pig.PigConfiguration
This key is used to turns off use of task reports in job statistics.
PIG_OPT_ACCUMULATOR - Static variable in class org.apache.pig.PigConfiguration
Boolean value used to enable or disable accumulator optimization.
PIG_OPT_FETCH - Static variable in class org.apache.pig.PigConfiguration
Boolean value used to enable or disable fetching without a mapreduce job for DUMP.
PIG_OPT_MULTIQUERY - Static variable in class org.apache.pig.PigConfiguration
Boolean value used to enable or disable multiquery optimization.
PIG_OPTIMIZER_RULES_DISABLED_KEY - Static variable in class org.apache.pig.PigConstants
"pig.optimizer.rules.disabled" is a comma-separated list of optimizer rules to disable; by default, all rules are enabled.
PIG_OPTIMIZER_RULES_KEY - Static variable in class org.apache.pig.impl.PigImplConstants
"pig.optimizer.rules" is a pig-internal properties key for serializing the set of disabled optimizer rules.
PIG_OUTPUT_COMMITTER_RECOVERY - Static variable in class org.apache.pig.PigConfiguration
This key is used to define whether to support recovery to handle the application master getting restarted.
PIG_OUTPUT_LAZY - Static variable in class org.apache.pig.PigConfiguration
This key is used to define whether PigOutputFormat will be wrapped with LazyOutputFormat so that jobs won't write empty part files if no output is generated
PIG_POISSON_SAMPLER_SAMPLE_RATE - Static variable in class org.apache.pig.PigConfiguration
For a given mean and a confidence, a sample rate is obtained from a poisson udf
PIG_PRINT_EXEC_PLAN - Static variable in class org.apache.pig.PigConfiguration
 
PIG_RANDOM_SAMPLER_SAMPLE_SIZE - Static variable in class org.apache.pig.PigConfiguration
This key used to control the sample size of RandomeSampleLoader for order-by.
PIG_REDUCE_STORES - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
PIG_ROUND_ROBIN_PARTITIONER_BATCH_SIZE - Static variable in class org.apache.pig.builtin.RoundRobinPartitioner
Deprecated.
Batch size for round robin partitioning.
PIG_SCHEMA_TUPLE_ALLOW_FORCE - Static variable in class org.apache.pig.PigConfiguration
 
PIG_SCHEMA_TUPLE_ENABLED - Static variable in class org.apache.pig.PigConfiguration
This key must be set to true by the user for code generation to be used.
PIG_SCHEMA_TUPLE_USE_IN_FOREACH - Static variable in class org.apache.pig.PigConfiguration
 
PIG_SCHEMA_TUPLE_USE_IN_FRJOIN - Static variable in class org.apache.pig.PigConfiguration
 
PIG_SCHEMA_TUPLE_USE_IN_MERGEJOIN - Static variable in class org.apache.pig.PigConfiguration
 
PIG_SCHEMA_TUPLE_USE_IN_UDF - Static variable in class org.apache.pig.PigConfiguration
 
PIG_SCRIPT_INFO_ENABLED - Static variable in class org.apache.pig.PigConfiguration
This key is used to turn off the inclusion of settings in the jobs.
PIG_SCRIPT_MAX_SIZE - Static variable in class org.apache.pig.PigConfiguration
Controls the size of Pig script stored in job xml.
PIG_SKEWEDJOIN_REDUCE_MEM - Static variable in class org.apache.pig.PigConfiguration
Memory available (in bytes) in reduce when calculating memory available for skewed join.
PIG_SKEWEDJOIN_REDUCE_MEMUSAGE - Static variable in class org.apache.pig.PigConfiguration
% of memory available for the input data.
PIG_SORT_READONCE_LOADFUNCS - Static variable in class org.apache.pig.PigConfiguration
Pig only reads once from datasource for LoadFuncs specified here during sort instead of loading once for sampling and loading again for partitioning.
PIG_SPARK_USE_NETTY_FILESERVER - Static variable in class org.apache.pig.PigConfiguration
Use Netty file server for Pig on Spark, true or false, default value is false
PIG_SPILL_COLLECTION_THRESHOLD_FRACTION - Static variable in class org.apache.pig.PigConfiguration
Spill will be triggered if the fraction of biggest heap exceeds the collection threshold.
PIG_SPILL_MEMORY_USAGE_THRESHOLD_FRACTION - Static variable in class org.apache.pig.PigConfiguration
Spill will be triggered if the fraction of biggest heap exceeds the usage threshold.
PIG_SPILL_UNUSED_MEMORY_THRESHOLD_SIZE - Static variable in class org.apache.pig.PigConfiguration
Spill will be triggered when unused memory falls below the threshold.
PIG_SPLIT_COMBINATION - Static variable in class org.apache.pig.PigConfiguration
Turns combine split files on or off
PIG_SPLIT_INDEX - Static variable in class org.apache.pig.impl.PigImplConstants
Indicate the split index of the task.
PIG_STORE_SCHEMA_DISAMBIGUATE - Static variable in class org.apache.pig.PigConfiguration
If set to false, automatic schema disambiguation gets disabled i.e.
PIG_STORE_SCHEMA_DISAMBIGUATE_DEFAULT - Static variable in class org.apache.pig.PigConfiguration
 
PIG_STREAMING_ENVIRONMENT - Static variable in class org.apache.pig.PigConfiguration
This key can be used to defined what properties will be set in the streaming environment.
PIG_STREAMING_UDF_PYTHON_COMMAND - Static variable in class org.apache.pig.PigConfiguration
This key can be used to configure the python command for python streaming udf.
PIG_TEMP_DIR - Static variable in class org.apache.pig.PigConfiguration
Location where pig stores temporary files for job setup
PIG_TEMP_FILE_COMPRESSION_CODEC - Static variable in class org.apache.pig.PigConfiguration
Compression codec used by intermediate storage TFileStorage only support gzip and lzo.
PIG_TEMP_FILE_COMPRESSION_STORAGE - Static variable in class org.apache.pig.PigConfiguration
This key is used to set the storage type used by intermediate file storage If pig.tmpfilecompression, default storage used is TFileStorage.
PIG_TEZ_AUTO_PARALLELISM - Static variable in class org.apache.pig.PigConfiguration
This key is used to configure auto parallelism in tez.
PIG_TEZ_AUTO_PARALLELISM_DISABLE_DAG_RECOVERY - Static variable in class org.apache.pig.PigConfiguration
This key is used to turn off dag recovery if there is auto parallelism.
PIG_TEZ_CONFIGURE_AM_MEMORY - Static variable in class org.apache.pig.PigConfiguration
If set, Pig will override tez.am.launch.cmd-opts and tez.am.resource.memory.mb to optimal
PIG_TEZ_DAG_STATUS_REPORT_INTERVAL - Static variable in class org.apache.pig.PigConfiguration
This key is used to configure the interval of dag status report in seconds.
PIG_TEZ_GRACE_PARALLELISM - Static variable in class org.apache.pig.PigConfiguration
This key is used to configure grace parallelism in tez.
PIG_TEZ_INPUT_SPLITS_MEM_THRESHOLD - Static variable in class org.apache.pig.PigConfiguration
Serialize input splits to disk if the input splits size exceeds a threshold to avoid hitting default RPC transfer size limit of 64MB.
PIG_TEZ_INPUT_SPLITS_MEM_THRESHOLD_DEFAULT - Static variable in class org.apache.pig.PigConfiguration
 
PIG_TEZ_OPT_UNION - Static variable in class org.apache.pig.PigConfiguration
This key is used to enable or disable union optimization in tez.
PIG_TEZ_OPT_UNION_SUPPORTED_STOREFUNCS - Static variable in class org.apache.pig.PigConfiguration
These keys are used to enable or disable tez union optimization for specific StoreFuncs.
PIG_TEZ_OPT_UNION_UNSUPPORTED_STOREFUNCS - Static variable in class org.apache.pig.PigConfiguration
 
PIG_TEZ_SESSION_REUSE - Static variable in class org.apache.pig.PigConfiguration
This key is used to define whether to reuse AM in Tez jobs.
PIG_TMP_PATH - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
the relative path that can be used to build a temporary place to store the output from a number of map-reduce tasks
PIG_UDF_PROFILE - Static variable in class org.apache.pig.PigConfiguration
Controls whether execution time of Pig UDFs should be tracked.
PIG_UDF_PROFILE_FREQUENCY - Static variable in class org.apache.pig.PigConfiguration
 
PIG_USER_CACHE_ENABLED - Static variable in class org.apache.pig.PigConfiguration
This key is turn on the user level cache
PIG_USER_CACHE_LOCATION - Static variable in class org.apache.pig.PigConfiguration
Location where additional jars are cached for the user Additional jar will be cached under PIG_USER_CACHE_LOCATION/${user.name}/.pigcache and will be re-used across the jobs run by the user if the jar has not changed
PIG_USER_CACHE_REPLICATION - Static variable in class org.apache.pig.PigConfiguration
Replication factor for files in pig jar cache
PIG_WHITELIST - Static variable in class org.apache.pig.PigConfiguration
Comma-delimited entries of commands/operators that must be allowed.
PigATSClient - Class in org.apache.pig.backend.hadoop
 
PigATSClient.ATSEvent - Class in org.apache.pig.backend.hadoop
 
PigAvroDatumReader - Class in org.apache.pig.piggybank.storage.avro
An avro GenericDatumReader which reads in avro data and converts them to pig data: tuples, bags, etc.
PigAvroDatumReader(Schema) - Constructor for class org.apache.pig.piggybank.storage.avro.PigAvroDatumReader
Construct where the writer's and reader's schemas are the same.
PigAvroDatumReader(Schema, Schema) - Constructor for class org.apache.pig.piggybank.storage.avro.PigAvroDatumReader
Construct given writer's and reader's schema.
PigAvroDatumWriter - Class in org.apache.pig.piggybank.storage.avro
An avro GenericDatumWriter to write pig data as Avro data.
PigAvroDatumWriter(Schema) - Constructor for class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
construct with output schema
PigAvroInputFormat - Class in org.apache.pig.piggybank.storage.avro
The InputFormat for avro data.
PigAvroInputFormat() - Constructor for class org.apache.pig.piggybank.storage.avro.PigAvroInputFormat
empty constructor
PigAvroInputFormat(Schema, boolean, Map<Path, Map<Integer, Integer>>, boolean) - Constructor for class org.apache.pig.piggybank.storage.avro.PigAvroInputFormat
constructor called by AvroStorage to pass in schema and ignoreBadFiles.
PigAvroOutputFormat - Class in org.apache.pig.piggybank.storage.avro
The OutputFormat for avro data.
PigAvroOutputFormat() - Constructor for class org.apache.pig.piggybank.storage.avro.PigAvroOutputFormat
default constructor
PigAvroOutputFormat(Schema) - Constructor for class org.apache.pig.piggybank.storage.avro.PigAvroOutputFormat
construct with specified output schema
PigAvroRecordReader - Class in org.apache.pig.piggybank.storage.avro
This is an implementation of record reader which reads in avro data and convert them into pairs.
PigAvroRecordReader(TaskAttemptContext, FileSplit, Schema, boolean, Map<Path, Map<Integer, Integer>>, boolean) - Constructor for class org.apache.pig.piggybank.storage.avro.PigAvroRecordReader
constructor to initialize input and avro data reader
PigAvroRecordWriter - Class in org.apache.pig.piggybank.storage.avro
The RecordWriter used to output pig results as avro data
PigAvroRecordWriter(DataFileWriter<Object>) - Constructor for class org.apache.pig.piggybank.storage.avro.PigAvroRecordWriter
construct with avro writer
PigBagWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigBagWritableComparator
 
PigBigDecimalRawBytesComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigDecimalRawBytesComparator
 
PigBigDecimalRawBytesPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigDecimalRawBytesPartitionComparator
 
PigBigDecimalRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigBigDecimalRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBigDecimalRawComparator
 
PigBigDecimalRawPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigDecimalRawPartitionComparator
 
PigBigDecimalWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigBigDecimalWritableComparator
 
PigBigIntegerRawBytesComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigIntegerRawBytesComparator
 
PigBigIntegerRawBytesPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigIntegerRawBytesPartitionComparator
 
PigBigIntegerRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigBigIntegerRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBigIntegerRawComparator
 
PigBigIntegerRawPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBigIntegerRawPartitionComparator
 
PigBigIntegerWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigBigIntegerWritableComparator
 
PigBooleanRawBytesComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBooleanRawBytesComparator
 
PigBooleanRawBytesPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBooleanRawBytesPartitionComparator
 
PigBooleanRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigBooleanRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBooleanRawComparator
 
PigBooleanRawPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBooleanRawPartitionComparator
 
PigBooleanWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigBooleanWritableComparator
 
PigBytesRawBytesComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBytesRawBytesComparator
 
PigBytesRawBytesPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBytesRawBytesPartitionComparator
 
PigBytesRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigBytesRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBytesRawComparator
 
PigBytesRawPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigBytesRawPartitionComparator
 
PigCharArrayWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigCharArrayWritableComparator
 
PigCombiner - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigCombiner() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner
 
PigCombiner.Combine - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigCommandFilter - Interface in org.apache.pig.validator
Interface defining Pig commands and a PigCommandFilter.validate(Command) method to operate on it
PigCommandFilter.Command - Enum in org.apache.pig.validator
 
PigCompletor - Class in org.apache.pig.tools.grunt
 
PigCompletor() - Constructor for class org.apache.pig.tools.grunt.PigCompletor
 
PigCompletorAliases - Class in org.apache.pig.tools.grunt
 
PigCompletorAliases(PigServer) - Constructor for class org.apache.pig.tools.grunt.PigCompletorAliases
 
PigConfiguration - Class in org.apache.pig
Container for static configuration strings, defaults, etc.
PigConstants - Class in org.apache.pig
 
pigContext - Variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
pigContext - Variable in class org.apache.pig.backend.hadoop.executionengine.HJob
 
PigContext - Class in org.apache.pig.impl
 
PigContext() - Constructor for class org.apache.pig.impl.PigContext
 
PigContext(Configuration) - Constructor for class org.apache.pig.impl.PigContext
 
PigContext(Properties) - Constructor for class org.apache.pig.impl.PigContext
 
PigContext(ExecType, Configuration) - Constructor for class org.apache.pig.impl.PigContext
 
PigContext(ExecType, Properties) - Constructor for class org.apache.pig.impl.PigContext
 
pigContext - Variable in class org.apache.pig.PigServer
 
pigContext - Variable in class org.apache.pig.tools.pigstats.PigStats
 
pigContext - Variable in class org.apache.pig.tools.pigstats.ScriptState
 
PigCounterHelper - Class in org.apache.pig.tools.counters
A helper class to deal with Hadoop counters in Pig.
PigCounterHelper() - Constructor for class org.apache.pig.tools.counters.PigCounterHelper
 
PigCounters - Enum in org.apache.pig
The following enum will contain the general counters that pig uses.
PigDateTimeRawBytesComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDateTimeRawBytesComparator
 
PigDateTimeRawBytesPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDateTimeRawBytesPartitionComparator
 
PigDateTimeRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigDateTimeRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigDateTimeRawComparator
 
PigDateTimeRawPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDateTimeRawPartitionComparator
 
PigDateTimeWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigDateTimeWritableComparator
 
PigDBAWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigDBAWritableComparator
 
PigDoubleRawBytesComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDoubleRawBytesComparator
 
PigDoubleRawBytesPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDoubleRawBytesPartitionComparator
 
PigDoubleRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigDoubleRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigDoubleRawComparator
 
PigDoubleRawPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigDoubleRawPartitionComparator
 
PigDoubleWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigDoubleWritableComparator
 
PigException - Exception in org.apache.pig
All exceptions in Pig are encapsulated in the PigException class.
PigException() - Constructor for exception org.apache.pig.PigException
Create a new PigException with null as the error message.
PigException(String) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message.
PigException(String, SourceLocation) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message.
PigException(Throwable) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified cause.
PigException(String, Throwable) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int, SourceLocation) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int, Throwable) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int, Throwable, SourceLocation) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int, byte) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int, byte, SourceLocation) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int, byte, Throwable, SourceLocation) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int, boolean) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int, byte, boolean) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int, byte, boolean, String, SourceLocation) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message and cause.
PigException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
PigException(String, int, byte, boolean, String, Throwable, SourceLocation) - Constructor for exception org.apache.pig.PigException
Create a new PigException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
PigFile - Class in org.apache.pig.impl.io
 
PigFile(String, boolean) - Constructor for class org.apache.pig.impl.io.PigFile
 
PigFile(String) - Constructor for class org.apache.pig.impl.io.PigFile
 
PigFileInputFormat<K,V> - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigFileInputFormat() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigFileInputFormat
 
PigFloatRawBytesComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigFloatRawBytesComparator
 
PigFloatRawBytesPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigFloatRawBytesPartitionComparator
 
PigFloatRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigFloatRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigFloatRawComparator
 
PigFloatRawPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigFloatRawPartitionComparator
 
PigFloatWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigFloatWritableComparator
 
PigGenericMapBase - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
This class is the base class for PigMapBase, which has slightly difference among different versions of hadoop.
PigGenericMapBase() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
 
PigGenericMapReduce - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
This class is the static Mapper & Reducer classes that are used by Pig to execute Pig Map Reduce jobs.
PigGenericMapReduce() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce
 
PigGenericMapReduce.Map - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigGenericMapReduce.MapWithComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
This "specialized" map class is ONLY to be used in pig queries with order by a udf.
PigGenericMapReduce.MapWithPartitionIndex - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Used by Skewed Join
PigGenericMapReduce.Reduce - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigGenericMapReduce.ReduceWithComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
This "specialized" reduce class is ONLY to be used in pig queries with order by a udf.
PigGraceShuffleVertexManager - Class in org.apache.pig.backend.hadoop.executionengine.tez.runtime
 
PigGraceShuffleVertexManager(VertexManagerPluginContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigGraceShuffleVertexManager
 
PigGroupingBagWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingBagWritableComparator
 
PigGroupingBigDecimalWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingBigDecimalWritableComparator
 
PigGroupingBigIntegerWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingBigIntegerWritableComparator
 
PigGroupingBooleanWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingBooleanWritableComparator
 
PigGroupingCharArrayWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingCharArrayWritableComparator
 
PigGroupingDateTimeWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingDateTimeWritableComparator
 
PigGroupingDBAWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingDBAWritableComparator
 
PigGroupingDoubleWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingDoubleWritableComparator
 
PigGroupingFloatWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingFloatWritableComparator
 
PigGroupingIntWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingIntWritableComparator
 
PigGroupingLongWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingLongWritableComparator
 
PigGroupingPartitionWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingPartitionWritableComparator
 
PigGroupingTupleWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigGroupingTupleWritableComparator
 
PigHadoopLogger - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
A singleton class that implements the PigLogger interface for use in map reduce context.
PigImplConstants - Class in org.apache.pig.impl
Private, internal constants for use by Pig itself.
PigInputFormat - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigInputFormat() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
PigInputFormat.RecordReaderFactory - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Helper class to create record reader
PigInputFormatSpark - Class in org.apache.pig.backend.hadoop.executionengine.spark.running
 
PigInputFormatSpark() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.running.PigInputFormatSpark
 
PigInputFormatTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.runtime
 
PigInputFormatTez() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigInputFormatTez
 
PigIntRawBytesComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigIntRawBytesComparator
 
PigIntRawBytesPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigIntRawBytesPartitionComparator
 
PigIntRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigIntRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigIntRawComparator
 
PigIntRawPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigIntRawPartitionComparator
 
PigIntWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigIntWritableComparator
 
PigJobControl - Class in org.apache.pig.backend.hadoop
extends the hadoop JobControl to remove the hardcoded sleep(5000) as most of this is private we have to use reflection See https://svn.apache.org/repos/asf/hadoop/common/branches/branch-0.23.1/hadoop-mapreduce-project/hadoop-mapreduce-client/hadoop-mapreduce-client-core/src/main/java/org/apache/hadoop/mapreduce/lib/jobcontrol/JobControl.java
PigJobControl(String, int) - Constructor for class org.apache.pig.backend.hadoop.PigJobControl
Construct a job control for a group of jobs.
PigJrubyLibrary - Class in org.apache.pig.scripting.jruby
This class provides the ability to present to Ruby a library that was written in Java.
PigJrubyLibrary() - Constructor for class org.apache.pig.scripting.jruby.PigJrubyLibrary
 
PigLineRecordWriter(DataOutputStream, byte) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTextOutputFormat.PigLineRecordWriter
 
pigLogger - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
PigLogger - Interface in org.apache.pig.backend.hadoop.executionengine.physicalLayer
An interface to allow aggregation of messages
pigLogger - Variable in class org.apache.pig.EvalFunc
Logger for aggregating warnings.
PigLongRawBytesComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigLongRawBytesComparator
 
PigLongRawBytesPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigLongRawBytesPartitionComparator
 
PigLongRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigLongRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigLongRawComparator
 
PigLongRawPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigLongRawPartitionComparator
 
PigLongWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigLongWritableComparator
 
PigMapBase - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigMapBase() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
 
PigMapBase.IllustratorContext - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigMapCounter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter.PigMapCounter
 
PigMapOnly - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
This class is the static Mapper class used by Pig to execute Pig map only jobs.
PigMapOnly() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapOnly
 
PigMapOnly.Map - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigMapReduce - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigMapReduce() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce
 
PigMapReduce.Reduce - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigMapReduce.Reduce.IllustratorContextImpl - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigMapReduce.Reduce.IllustratorContextImpl.IllustratorValueIterable - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigMapReduce.Reduce.IllustratorContextImpl.IllustratorValueIterator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigMapReduceCounter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigMapReduceCounter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter
 
PigMapReduceCounter.PigMapCounter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
This class is the used only for simple RANK operation, namely row number mode.
PigMapReduceCounter.PigReduceCounter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
This class is the used for RANK BY operations, independently if it is dense or not.
PigNullableWritable - Class in org.apache.pig.impl.io
A base class for all types that pig uses to move data between map and reduce.
PigNullableWritable() - Constructor for class org.apache.pig.impl.io.PigNullableWritable
 
PigOutputCommitter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
A specialization of the default FileOutputCommitter to allow pig to inturn delegate calls to the OutputCommiter(s) of the StoreFunc(s)' OutputFormat(s).
PigOutputCommitter(TaskAttemptContext, List<POStore>, List<POStore>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
PigOutputCommitterTez(TaskAttemptContext, List<POStore>, List<POStore>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigOutputFormatTez.PigOutputCommitterTez
 
PigOutputFormat - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
The better half of PigInputFormat which is responsible for the Store functionality.
PigOutputFormat() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
 
PigOutputFormat.PigRecordWriter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Wrapper class which will delegate calls to the actual RecordWriter - this should only get called in the single store case.
PigOutputFormatTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.runtime
 
PigOutputFormatTez() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigOutputFormatTez
 
PigOutputFormatTez.PigOutputCommitterTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.runtime
 
PigParserNode - Class in org.apache.pig.parser
 
PigParserNode(Token, String, int) - Constructor for class org.apache.pig.parser.PigParserNode
 
PigParserNode(Token, String, Token) - Constructor for class org.apache.pig.parser.PigParserNode
 
PigParserNode(PigParserNode) - Constructor for class org.apache.pig.parser.PigParserNode
 
PigParserNode.InvocationPoint - Class in org.apache.pig.parser
 
PigParserNodeAdaptor - Class in org.apache.pig.parser
 
PigPlans(LogicalPlan) - Constructor for class org.apache.pig.tools.ToolsPigServer.PigPlans
 
PigProcessor - Class in org.apache.pig.backend.hadoop.executionengine.tez.runtime
 
PigProcessor(ProcessorContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
PigProgressable - Interface in org.apache.pig.backend.hadoop.executionengine.physicalLayer
Pig's progress indicator.
PigProgressNotificationListener - Interface in org.apache.pig.tools.pigstats
Should be implemented by an object that wants to receive notifications from PigRunner.
PigRecognitionException - Exception in org.apache.pig.parser
Subclass of Antlr RecognitionException which should be the parent class of all parser related exception classes.
PigRecognitionException(IntStream, SourceLocation) - Constructor for exception org.apache.pig.parser.PigRecognitionException
 
PigRecordReader - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
A wrapper around the actual RecordReader and loadfunc - this is needed for two reasons 1) To intercept the initialize call from hadoop and initialize the underlying actual RecordReader with the right Context object - this is achieved by looking up the Context corresponding to the input split this Reader is supposed to process 2) We need to give hadoop consistent key-value types - text and tuple respectively - so PigRecordReader will call underlying Loader's getNext() to get the Tuple value - the key is null text since key is not used in input to map() in Pig.
PigRecordReader(InputFormat<?, ?>, PigSplit, LoadFunc, TaskAttemptContext, long) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigRecordReader
 
PigRecordWriter(RecordWriter, StoreFuncDecorator, PigOutputFormat.Mode) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat.PigRecordWriter
 
PigReduceCounter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter.PigReduceCounter
 
PigReducerEstimator - Interface in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Interface to implement when you want to use a custom approach to estimating the number of reducers for a job.
PigRunner - Class in org.apache.pig
A utility to help run PIG scripts within a Java program.
PigRunner() - Constructor for class org.apache.pig.PigRunner
 
PigRunner.ReturnCode - Class in org.apache.pig
 
PigSchema2Avro - Class in org.apache.pig.piggybank.storage.avro
This class contains functions to convert Pig schema to Avro.
PigSchema2Avro() - Constructor for class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
 
PigSecondaryKeyComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigSecondaryKeyComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSecondaryKeyComparator
 
PigSecondaryKeyGroupComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigSecondaryKeyGroupComparator
 
PigSequenceFileInputFormat<K,V> - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigSequenceFileInputFormat() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSequenceFileInputFormat
 
PigServer - Class in org.apache.pig
A class for Java programs to connect to Pig.
PigServer(String) - Constructor for class org.apache.pig.PigServer
 
PigServer(String, Properties) - Constructor for class org.apache.pig.PigServer
 
PigServer(Properties) - Constructor for class org.apache.pig.PigServer
 
PigServer(ExecType) - Constructor for class org.apache.pig.PigServer
 
PigServer(ExecType, Properties) - Constructor for class org.apache.pig.PigServer
 
PigServer(ExecType, Configuration) - Constructor for class org.apache.pig.PigServer
 
PigServer(PigContext) - Constructor for class org.apache.pig.PigServer
 
PigServer(PigContext, boolean) - Constructor for class org.apache.pig.PigServer
 
PigServer.Graph - Class in org.apache.pig
 
pigSplit - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat.RecordReaderFactory
 
PigSplit - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
The main split class that maintains important information about the input split.
PigSplit() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
PigSplit(InputSplit[], int, List<OperatorKey>, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
PigStats - Class in org.apache.pig.tools.pigstats
PigStats encapsulates the statistics collected from a running script.
PigStats() - Constructor for class org.apache.pig.tools.pigstats.PigStats
 
PigStats.JobGraph - Class in org.apache.pig.tools.pigstats
JobGraph is an OperatorPlan whose members are JobStats
PigStats.JobGraphPrinter - Class in org.apache.pig.tools.pigstats
This class prints a JobGraph
PigStatsOutputSizeReader - Interface in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Interface to implement when you want to customize the way of computing the size of output in PigStats.
PigStatsUtil - Class in org.apache.pig.tools.pigstats
A utility class for Pig Statistics
PigStatsUtil() - Constructor for class org.apache.pig.tools.pigstats.PigStatsUtil
 
PigStatusReporter - Class in org.apache.pig.tools.pigstats
 
PigStorage - Class in org.apache.pig.builtin
A load function that parses a line of input into fields using a character delimiter.
PigStorage() - Constructor for class org.apache.pig.builtin.PigStorage
 
PigStorage(String) - Constructor for class org.apache.pig.builtin.PigStorage
Constructs a Pig loader that uses specified character as a field delimiter.
PigStorage(String, String) - Constructor for class org.apache.pig.builtin.PigStorage
Constructs a Pig loader that uses specified character as a field delimiter.
PigStorageSchema - Class in org.apache.pig.piggybank.storage
Deprecated.
Use PigStorage with a -schema option instead
PigStorageSchema() - Constructor for class org.apache.pig.piggybank.storage.PigStorageSchema
Deprecated.
 
PigStorageSchema(String) - Constructor for class org.apache.pig.piggybank.storage.PigStorageSchema
Deprecated.
 
PigStreaming - Class in org.apache.pig.builtin
The default implementation of PigStreamingBase.
PigStreaming() - Constructor for class org.apache.pig.builtin.PigStreaming
The constructor that uses the default field delimiter.
PigStreaming(String) - Constructor for class org.apache.pig.builtin.PigStreaming
The constructor that accepts a user-specified field delimiter.
PigStreamingBase - Class in org.apache.pig
The interface is used for the custom mapping of - a Tuple to a byte array.
PigStreamingBase() - Constructor for class org.apache.pig.PigStreamingBase
 
PigStreamingUDF - Class in org.apache.pig.impl.streaming
 
PigStreamingUDF() - Constructor for class org.apache.pig.impl.streaming.PigStreamingUDF
 
PigStreamingUDF(Schema.FieldSchema) - Constructor for class org.apache.pig.impl.streaming.PigStreamingUDF
 
PigTextInputFormat - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigTextInputFormat() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTextInputFormat
 
PigTextOutputFormat - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigTextOutputFormat(byte) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTextOutputFormat
 
PigTextOutputFormat.PigLineRecordWriter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigTextRawBytesComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTextRawBytesComparator
 
PigTextRawBytesPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTextRawBytesPartitionComparator
 
PigTextRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigTextRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTextRawComparator
 
PigTextRawPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTextRawPartitionComparator
 
PigTezProgressNotificationListener - Class in org.apache.pig.tools.pigstats.tez
Should be implemented by an object that wants to receive notifications from PigRunner.
PigTezProgressNotificationListener() - Constructor for class org.apache.pig.tools.pigstats.tez.PigTezProgressNotificationListener
 
pigToGroovy(Object) - Static method in class org.apache.pig.scripting.groovy.GroovyUtils
Converts an object created on the Pig side to its Groovy counterpart.
pigToPython(Object) - Static method in class org.apache.pig.scripting.jython.JythonUtils
 
pigToRuby(Ruby, Object) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
This is the method which provides conversion from Pig to Ruby.
pigToRuby(Ruby, Tuple) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
pigToRuby(Ruby, Boolean) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
pigToRuby(Ruby, DataBag) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
pigToRuby(Ruby, Schema) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
pigToRuby(Ruby, Map<T, ?>) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine for Pig Maps.
pigToRuby(Ruby, DataByteArray) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
pigToRuby(Ruby, String) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
pigToRuby(Ruby, Integer) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
pigToRuby(Ruby, Long) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
pigToRuby(Ruby, Float) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
pigToRuby(Ruby, Double) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
PigToStream - Interface in org.apache.pig
Deprecated.
PigTupleDefaultRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigTupleDefaultRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleDefaultRawComparator
 
PigTupleSortBytesComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTupleSortBytesComparator
 
PigTupleSortBytesPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTupleSortBytesPartitionComparator
 
PigTupleSortComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigTupleSortComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleSortComparator
 
PigTupleSortPartitionComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators.PigTupleSortPartitionComparator
 
pigTupleToPyTuple(Tuple) - Static method in class org.apache.pig.scripting.jython.JythonUtils
 
PigTupleWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigTupleWritableComparator
 
pigVersion - Variable in class org.apache.pig.tools.pigstats.ScriptState
 
PigWarnCounter - Interface in org.apache.pig.tools.pigstats
 
PigWarning - Enum in org.apache.pig
An enum to enumerate the warning types in Pig
PigWritableComparator(Class) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigWritableComparator
 
PigWritableComparators - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigWritableComparators
 
PigWritableComparators.PigBigDecimalRawBytesComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigBigDecimalRawBytesPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigBigDecimalRawPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigBigIntegerRawBytesComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigBigIntegerRawBytesPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigBigIntegerRawPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigBooleanRawBytesComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigBooleanRawBytesPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigBooleanRawPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigBytesRawBytesComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigBytesRawBytesPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigBytesRawPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigDateTimeRawBytesComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigDateTimeRawBytesPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigDateTimeRawPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigDoubleRawBytesComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigDoubleRawBytesPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigDoubleRawPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigFloatRawBytesComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigFloatRawBytesPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigFloatRawPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigIntRawBytesComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigIntRawBytesPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigIntRawPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigLongRawBytesComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigLongRawBytesPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigLongRawPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigTextRawBytesComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigTextRawBytesPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigTextRawPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigTupleSortBytesComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigTupleSortBytesPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigWritableComparators.PigTupleSortPartitionComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
pinOption(Integer) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
pkg - Variable in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
pkgr - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
pkgr - Variable in class org.apache.pig.data.ReadOnceBag
 
plan - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
PLAN - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
plan - Variable in class org.apache.pig.impl.plan.PlanDumper
 
plan - Variable in class org.apache.pig.newplan.Operator
 
plan - Variable in class org.apache.pig.newplan.optimizer.PlanOptimizer
 
plan - Variable in class org.apache.pig.newplan.PlanDumper
 
plan - Variable in class org.apache.pig.newplan.PlanVisitor
 
plan - Variable in class org.apache.pig.newplan.PlanWalker
 
PlanDumper<E extends Operator,P extends OperatorPlan<E>,S extends OperatorPlan<? extends Operator>> - Class in org.apache.pig.impl.plan
This class dumps a nested plan to a print stream.
PlanDumper(P, PrintStream) - Constructor for class org.apache.pig.impl.plan.PlanDumper
 
PlanDumper - Class in org.apache.pig.newplan
This class dumps a nested plan to a print stream.
PlanDumper(BaseOperatorPlan, PrintStream) - Constructor for class org.apache.pig.newplan.PlanDumper
 
PlanEdge - Class in org.apache.pig.newplan
 
PlanEdge() - Constructor for class org.apache.pig.newplan.PlanEdge
 
PlanEdge(int) - Constructor for class org.apache.pig.newplan.PlanEdge
 
PlanException - Exception in org.apache.pig.impl.plan
 
PlanException() - Constructor for exception org.apache.pig.impl.plan.PlanException
Create a new PlanException with null as the error message.
PlanException(String) - Constructor for exception org.apache.pig.impl.plan.PlanException
Create a new PlanException with the specified message and cause.
PlanException(Throwable) - Constructor for exception org.apache.pig.impl.plan.PlanException
Create a new PlanException with the specified cause.
PlanException(String, Throwable) - Constructor for exception org.apache.pig.impl.plan.PlanException
Create a new PlanException with the specified message and cause.
PlanException(String, int) - Constructor for exception org.apache.pig.impl.plan.PlanException
Create a new PlanException with the specified message and cause.
PlanException(String, int, Throwable) - Constructor for exception org.apache.pig.impl.plan.PlanException
Create a new PlanException with the specified message and cause.
PlanException(String, int, byte) - Constructor for exception org.apache.pig.impl.plan.PlanException
Create a new PlanException with the specified message and cause.
PlanException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.impl.plan.PlanException
Create a new PlanException with the specified message and cause.
PlanException(String, int, boolean) - Constructor for exception org.apache.pig.impl.plan.PlanException
Create a new PlanException with the specified message and cause.
PlanException(String, int, byte, boolean) - Constructor for exception org.apache.pig.impl.plan.PlanException
Create a new PlanException with the specified message and cause.
PlanException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.impl.plan.PlanException
Create a new PlanException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
PlanException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.impl.plan.PlanException
Create a new PlanException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
PlanGenerationFailureException - Exception in org.apache.pig.parser
 
PlanGenerationFailureException(IntStream, SourceLocation, Exception) - Constructor for exception org.apache.pig.parser.PlanGenerationFailureException
 
planHasNonDeterministicUdf(LogicalExpressionPlan) - Static method in class org.apache.pig.newplan.logical.rules.OptimizerUtils
Helper method to determine if the logical expression plan for a Filter contains non-deterministic operations and should therefore be treated extra carefully during optimization.
PlanHelper - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.util
Utility class with a few helper functions to deal with physical plans.
planLeafOps - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
PlanOptimizer - Class in org.apache.pig.newplan.optimizer
The core class of the optimizer.
PlanOptimizer(OperatorPlan, List<Set<Rule>>, int) - Constructor for class org.apache.pig.newplan.optimizer.PlanOptimizer
 
PlanPrinter<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans
 
PlanPrinter(P) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
PlanPrinter(P, PrintStream) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
plans - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
plans - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
plans - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
PlanTransformListener - Interface in org.apache.pig.newplan.optimizer
An interface to describe listeners that are notified when a plan is modified.
PlanValidationException - Exception in org.apache.pig.impl.plan
 
PlanValidationException() - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with null as the error message.
PlanValidationException(String) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message and cause.
PlanValidationException(Operator, String) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message and cause.
PlanValidationException(Throwable) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified cause.
PlanValidationException(String, Throwable) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message and cause.
PlanValidationException(String, int) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message and cause.
PlanValidationException(Operator, String, int) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message and cause.
PlanValidationException(String, int, Throwable) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message and cause.
PlanValidationException(String, int, byte) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message and cause.
PlanValidationException(Operator, String, int, byte) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message and cause.
PlanValidationException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message and cause.
PlanValidationException(String, int, boolean) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message and cause.
PlanValidationException(String, int, byte, boolean) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message and cause.
PlanValidationException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
PlanValidationException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.impl.plan.PlanValidationException
Create a new PlanValidationException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
PlanVisitor<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.impl.plan
A visitor mechanism for navigating and operating on a plan of Operators.
PlanVisitor(P, PlanWalker<O, P>) - Constructor for class org.apache.pig.impl.plan.PlanVisitor
 
PlanVisitor - Class in org.apache.pig.newplan
A visitor mechanism for navigating and operating on a plan of Operators.
PlanVisitor(OperatorPlan, PlanWalker) - Constructor for class org.apache.pig.newplan.PlanVisitor
 
PlanWalker<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.impl.plan
PlanWalker encapsulates the logic to traverse a plan.
PlanWalker(P) - Constructor for class org.apache.pig.impl.plan.PlanWalker
 
PlanWalker - Class in org.apache.pig.newplan
 
PlanWalker(OperatorPlan) - Constructor for class org.apache.pig.newplan.PlanWalker
 
PluckTuple - Class in org.apache.pig.builtin
This is a UDF which allows the user to specify a string prefix, and then filter for the columns in a relation that begin with that prefix.
PluckTuple(String) - Constructor for class org.apache.pig.builtin.PluckTuple
 
PluckTuple(String, String) - Constructor for class org.apache.pig.builtin.PluckTuple
 
plus(ThreadContext, IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubyDataByteArray
This method accepts as an argument anything that could be passed to set (ie a RubyDataByteArray, RubyString, or byte array).
POAnd - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
Boolean and operator.
POAnd(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POAnd
 
POAnd(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POAnd
 
POBinCond - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
POBinCond(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
POBinCond(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
POBinCond(OperatorKey, int, ExpressionOperator, ExpressionOperator, ExpressionOperator) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
POBloomFilterRearrangeTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
 
POBloomFilterRearrangeTez(POLocalRearrangeTez, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBloomFilterRearrangeTez
 
POBroadcastSpark - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POBroadcastSpark(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POBroadcastSpark
 
POBroadcastSpark(POBroadcastSpark) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POBroadcastSpark
 
POBuildBloomRearrangeTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
This operator writes out the key value for the hash join reduce operation similar to POLocalRearrangeTez.
POBuildBloomRearrangeTez(POLocalRearrangeTez, boolean, int, int, int, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
POCast - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
This is just a cast that converts DataByteArray into either String or Integer.
POCast(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
POCast(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
POCollectedGroup - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The collected group operator is a special operator used when users give the hint 'using "collected"' in a group by clause.
POCollectedGroup(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
POCollectedGroup(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
POCollectedGroup(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
POCollectedGroup(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
POCounter - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
This operator is part of the RANK operator implementation.
POCounter(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
POCounter(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
POCounter(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
POCounter(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
POCounter(POCounter) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
POCounter(OperatorKey, int, List, List<PhysicalPlan>, List<Boolean>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
POCounterStatsTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
POCounterStatsTez is used to group counters from previous vertex POCounterTez tasks
POCounterStatsTez(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
POCounterTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
 
POCounterTez(POCounter) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterTez
 
POCross - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
Recover this class for nested cross operation.
POCross(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
POCross(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
POCross(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
POCross(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
PODemux - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The MapReduce Demultiplexer operator.
PODemux(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Constructs an operator with the specified key.
PODemux(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Constructs an operator with the specified key and degree of parallelism.
PODemux(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Constructs an operator with the specified key and inputs.
PODemux(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Constructs an operator with the specified key, degree of parallelism and inputs.
PODistinct - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
Find the distinct set of tuples in a bag.
PODistinct(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
PODistinct(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
PODistinct(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
PODistinct(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
POFilter - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
This is an implementation of the Filter operator.
POFilter(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
 
POFilter(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
 
POFilter(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
 
POFilter(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
 
POForEach - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POForEach(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
POForEach(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
POForEach(OperatorKey, List) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
POForEach(OperatorKey, int, List<PhysicalPlan>, List<Boolean>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
POForEach(OperatorKey, int, List<PhysicalPlan>, List<Boolean>, Schema) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
POFRJoin - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The operator models the join keys using the Local Rearrange operators which are configured with the plan specified by the user.
POFRJoin(OperatorKey, int, List<PhysicalOperator>, List<List<PhysicalPlan>>, List<List<Byte>>, FileSpec[], int, boolean, Tuple) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
POFRJoin(OperatorKey, int, List<PhysicalOperator>, List<List<PhysicalPlan>>, List<List<Byte>>, FileSpec[], int, boolean, Tuple, Schema[], Schema[]) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
POFRJoin(POFRJoin) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
POFRJoin.TupleToMapKey - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POFRJoinSpark - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POFRJoinSpark(POFRJoin) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoinSpark
 
POFRJoinTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
POFRJoinTez is used on the backend to load replicated table from Tez ShuffleUnorderedKVInput and load fragmented table from data pipeline.
POFRJoinTez(POFRJoin, List<String>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POFRJoinTez
 
POGlobalRearrange - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
Dummy operator to test MRCompiler.
POGlobalRearrange(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
POGlobalRearrange(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
POGlobalRearrange(OperatorKey, List) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
POGlobalRearrange(OperatorKey, int, List) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
POGlobalRearrange(POGlobalRearrange) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
POGlobalRearrangeSpark - Class in org.apache.pig.backend.hadoop.executionengine.spark.operator
POGlobalRearrange for spark mode
POGlobalRearrangeSpark(POGlobalRearrange) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.operator.POGlobalRearrangeSpark
 
POIdentityInOutTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
POIdentityInOutTez is used to pass through tuples as is to next vertex from previous vertex's POLocalRearrangeTez.
POIdentityInOutTez(OperatorKey, POLocalRearrange, String) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POIdentityInOutTez
 
POIsNull - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
POIsNull(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POIsNull
 
POIsNull(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POIsNull
 
POIsNull(OperatorKey, int, ExpressionOperator) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POIsNull
 
PoissonSampleConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
PoissonSampleConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.PoissonSampleConverter
 
PoissonSampleLoader - Class in org.apache.pig.impl.builtin
See "Skewed Join sampler" in http://wiki.apache.org/pig/PigSampler
PoissonSampleLoader(String, String) - Constructor for class org.apache.pig.impl.builtin.PoissonSampleLoader
 
POJoinGroupSpark - Class in org.apache.pig.backend.hadoop.executionengine.spark.operator
Collapse POLocalRearrange,POGlobalRearrange and POPackage to POJoinGroupSpark to reduce unnecessary map operations in the join/group
POJoinGroupSpark(List<POLocalRearrange>, POGlobalRearrangeSpark, POPackage) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.operator.POJoinGroupSpark
 
POLimit - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POLimit(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
POLimit(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
POLimit(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
POLimit(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
POLoad - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The load operator which is used in two ways: 1) As a local operator it can be used to load files 2) In the Map Reduce setting, it is used to create jobs from MapReduce operators which keep the loads and stores in the Map and Reduce Plans till the job is created
POLoad(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
POLoad(OperatorKey, FileSpec) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
POLoad(OperatorKey, int, FileSpec) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
POLoad(OperatorKey, LoadFunc) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
POLocalRearrange - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The local rearrange operator is a part of the co-group implementation.
POLocalRearrange(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
POLocalRearrange(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
POLocalRearrange(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
POLocalRearrange(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
POLocalRearrange(POLocalRearrange) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
POLocalRearrangeTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
POLocalRearrangeTez is used to write to a Tez OrderedPartitionedKVOutput (shuffle) or UnorderedKVOutput (broadcast)
POLocalRearrangeTez(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
POLocalRearrangeTez(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
POLocalRearrangeTez(POLocalRearrange) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
POLocalRearrangeTezFactory - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
 
POLocalRearrangeTezFactory(String, NodeIdGenerator) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTezFactory
 
POLocalRearrangeTezFactory.LocalRearrangeType - Enum in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
 
POMapLookUp - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
POMapLookUp(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
POMapLookUp(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
POMapLookUp(OperatorKey, int, String) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
POMergeCogroup - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POMergeCogroup(OperatorKey, List<PhysicalOperator>, POLocalRearrange[], int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
POMergeJoin - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
This operator implements merge join algorithm to do map side joins.
POMergeJoin(OperatorKey, int, List<PhysicalOperator>, MultiMap<PhysicalOperator, PhysicalPlan>, List<List<Byte>>, LOJoin.JOINTYPE, Schema, Schema, Schema) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
POMergeJoin.TuplesToSchemaTupleList - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
This is a class that extends ArrayList, making it easy to provide on the fly conversion from Tuple to SchemaTuple.
PONative - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
PONative(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PONative
 
PONegative - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
PONegative(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
PONegative(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
PONegative(OperatorKey, int, ExpressionOperator) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
PONot - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
Boolean not operator.
PONot(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONot
 
PONot(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONot
 
POOptimizedForEach - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
A specialized version of POForeach with the difference that in getNext(), it knows that "input" has already been attached by its input operator which SHOULD be POJoinPackage
POOptimizedForEach(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POOptimizedForEach
 
POOptimizedForEach(OperatorKey, int, List) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POOptimizedForEach
 
POOptimizedForEach(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POOptimizedForEach
 
POOptimizedForEach(OperatorKey, List) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POOptimizedForEach
 
POOptimizedForEach(OperatorKey, int, List<PhysicalPlan>, List<Boolean>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POOptimizedForEach
 
POOptimizeDisabler - Class in org.apache.pig.pen
 
POOptimizeDisabler(OperatorPlan) - Constructor for class org.apache.pig.pen.POOptimizeDisabler
 
POOr - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
Boolean or operator.
POOr(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POOr
 
POOr(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POOr
 
POPackage - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The package operator that packages the globally rearranged tuples into output format as required by co-group.
POPackage(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
POPackage(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
POPackage(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
POPackage(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
POPackage(OperatorKey, int, List<PhysicalOperator>, Packager) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
POPackage(POPackage) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
POPackage.POPackageTupleBuffer - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POPackageAnnotator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
This visitor visits the MRPlan and does the following for each MROper - visits the POPackage in the reduce plan and finds the corresponding POLocalRearrange(s) (either in the map plan of the same oper OR reduce plan of predecessor MROper).
POPackageAnnotator(MROperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.POPackageAnnotator
 
POPackageTupleBuffer(int, Object, Iterator<NullableTuple>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage.POPackageTupleBuffer
 
POPartialAgg - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
Do partial aggregation in map plan.
POPartialAgg(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
POPartialAgg(OperatorKey, boolean) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
POPartitionRearrange - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The partition rearrange operator is a part of the skewed join implementation.
POPartitionRearrange(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartitionRearrange
 
POPartitionRearrange(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartitionRearrange
 
POPartitionRearrange(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartitionRearrange
 
POPartitionRearrange(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartitionRearrange
 
POPartitionRearrangeTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
The partition rearrange operator is a part of the skewed join implementation.
POPartitionRearrangeTez(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POPartitionRearrangeTez
 
POPartitionRearrangeTez(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POPartitionRearrangeTez
 
POPoissonSample - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POPoissonSample(OperatorKey, int, int, float, long) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
POPoissonSampleSpark - Class in org.apache.pig.backend.hadoop.executionengine.spark.operator
 
POPoissonSampleSpark(OperatorKey, int, int, float, long) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.operator.POPoissonSampleSpark
 
POPreCombinerLocalRearrange - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
A specialized local rearrange operator which behaves like the regular local rearrange in the getNext() as far as getting its input and constructing the "key" out of the input.
POPreCombinerLocalRearrange(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
POPreCombinerLocalRearrange(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
POPreCombinerLocalRearrange(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
POPreCombinerLocalRearrange(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
POPrinter - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer
 
POPrinter(PrintStream, PhysicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POPrinter
 
POProject - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
Implements the overloaded form of the project operator.
POProject(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
POProject(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
POProject(OperatorKey, int, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
POProject(OperatorKey, int, ArrayList<Integer>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
populateTokenCache(Configuration, Credentials) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.SecurityHelper
 
popWalker() - Method in class org.apache.pig.impl.plan.PlanVisitor
Pop the next to previous walker off of the stack and set it as the current walker.
popWalker() - Method in class org.apache.pig.newplan.PlanVisitor
Pop the next to previous walker off of the stack and set it as the current walker.
PORank - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
This operator is part of the RANK operator implementation.
PORank(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
PORank(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
PORank(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
PORank(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
PORank(PORank) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
PORank(OperatorKey, int, List, List<PhysicalPlan>, List<Boolean>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
PORankTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
 
PORankTez(PORank) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.PORankTez
 
POReduceBySpark - Class in org.apache.pig.backend.hadoop.executionengine.spark.operator
ReduceBy operator that maps to Sparks ReduceBy.
POReduceBySpark(OperatorKey, int, List<PhysicalPlan>, List<Boolean>, POPackage, POLocalRearrange) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
PORegexp - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
PORegexp(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORegexp
 
PORegexp(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORegexp
 
PORelationToExprProject - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
Implements a specialized form of POProject which is used *ONLY* in the following case: This project is Project(*) introduced after a relational operator to supply a bag as output (as an expression).
PORelationToExprProject(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORelationToExprProject
 
PORelationToExprProject(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORelationToExprProject
 
PORelationToExprProject(OperatorKey, int, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORelationToExprProject
 
PORelationToExprProject(OperatorKey, int, ArrayList<Integer>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORelationToExprProject
 
POReservoirSample - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POReservoirSample(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POReservoirSample
 
POReservoirSample(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POReservoirSample
 
POReservoirSample(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POReservoirSample
 
POReservoirSample(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POReservoirSample
 
POReservoirSample(OperatorKey, int, List<PhysicalOperator>, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POReservoirSample
 
POSampleSortSpark - Class in org.apache.pig.backend.hadoop.executionengine.spark.operator
 
POSampleSortSpark(POSort) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.operator.POSampleSortSpark
 
POShuffledValueInputTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
POShuffledValueInputTez is used read tuples from a Tez Intermediate output from a shuffle edge To be used with POValueOutputTez.
POShuffledValueInputTez(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffledValueInputTez
 
POShuffleTezLoad - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
 
POShuffleTezLoad(POPackage) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffleTezLoad
 
POSimpleTezLoad - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
POSimpleTezLoad is used on the backend to read tuples from a Tez MRInput
POSimpleTezLoad(OperatorKey, LoadFunc) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POSimpleTezLoad
 
POSITIVE_INFINITY() - Static method in class org.apache.pig.builtin.BigDecimalWrapper
 
POSITIVE_INFINITY() - Static method in class org.apache.pig.builtin.BigIntegerWrapper
 
POSkewedJoin - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The PhysicalOperator that represents a skewed join.
POSkewedJoin(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
POSkewedJoin(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
POSkewedJoin(OperatorKey, List<PhysicalOperator>, boolean[]) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
POSkewedJoin(OperatorKey, int, List<PhysicalOperator>, boolean[]) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
POSort - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
This implementation is applicable for both the physical plan and for the local backend, as the conversion of physical to mapreduce would see the SORT operator and take necessary steps to convert it to a quantile and a sort job.
POSort(OperatorKey, int, List, List<PhysicalPlan>, List<Boolean>, POUserComparisonFunc) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
POSort(OperatorKey, int, List) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
POSort(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
POSort(OperatorKey, List) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
POSort(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
POSort.SortComparator - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POSort.UDFSortComparator - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POSortedDistinct - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
This operator is a variation of PODistinct, the input to this operator must be sorted already.
POSortedDistinct(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSortedDistinct
 
POSortedDistinct(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSortedDistinct
 
POSortedDistinct(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSortedDistinct
 
POSortedDistinct(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSortedDistinct
 
POSplit - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The MapReduce Split operator.
POSplit(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
Constructs an operator with the specified key
POSplit(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
Constructs an operator with the specified key and degree of parallelism
POSplit(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
Constructs an operator with the specified key and inputs
POSplit(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
Constructs an operator with the specified key, degree of parallelism and inputs
POStatus - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer
POStatus is a set of flags used to communicate the status of Pig's operator pipeline to consumers.
POStatus() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
 
poStore - Variable in class org.apache.pig.backend.hadoop.executionengine.HJob
 
POStore - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The store operator which is used in two ways: 1) As a local operator it can be used to store files 2) In the Map Reduce setting, it is used to create jobs from MapReduce operators which keep the loads and stores in the Map and Reduce Plans till the job is created
POStore(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
POStore(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
POStore(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
POStore(POStore) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
POStoreImpl - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
This class is used to specify the actual behavior of the store operator just when ready to start execution.
POStoreImpl() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStoreImpl
 
POStoreTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
POStoreTez is used to write to a Tez MROutput
POStoreTez(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POStoreTez
 
POStoreTez(POStore) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POStoreTez
 
POStream - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POStream(OperatorKey, ExecutableManager, StreamingCommand, Properties) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
POUnion - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The union operator that combines the two inputs into a single stream.
POUnion(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
 
POUnion(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
 
POUnion(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
 
POUnion(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
 
POUserComparisonFunc - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
POUserComparisonFunc(OperatorKey, int, List, FuncSpec, ComparisonFunc) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
POUserComparisonFunc(OperatorKey, int, List, FuncSpec) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
POUserFunc - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
POUserFunc(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
POUserFunc(OperatorKey, int, List<PhysicalOperator>, FuncSpec) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
POUserFunc(OperatorKey, int, List<PhysicalOperator>, FuncSpec, EvalFunc) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
POValueInputTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
POValueInputTez is used read tuples from a Tez Intermediate output from a 1-1 edge
POValueInputTez(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueInputTez
 
POValueOutputTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
 
POValueOutputTez(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
POValueOutputTez.EmptyWritable - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.operator
 
POW - Class in org.apache.pig.piggybank.evaluation.math
math.POW implements a binding to the Java function Math.pow(double,double).
POW() - Constructor for class org.apache.pig.piggybank.evaluation.math.POW
 
predeployedJars - Variable in class org.apache.pig.impl.PigContext
 
PredicatePushDownFilterExtractor - Class in org.apache.pig.newplan
We traverse the expression plan bottom up and separate it into two plans - pushdownExprPlan, plan that can be pushed down to the loader and - filterExprPlan, remaining plan that needs to be evaluated by pig If the predicate is not removable then filterExprPlan will not have the pushdownExprPlan removed.
PredicatePushDownFilterExtractor(LogicalExpressionPlan, List<String>, List<Expression.OpType>) - Constructor for class org.apache.pig.newplan.PredicatePushDownFilterExtractor
 
PredicatePushdownOptimizer - Class in org.apache.pig.newplan.logical.rules
 
PredicatePushdownOptimizer(String) - Constructor for class org.apache.pig.newplan.logical.rules.PredicatePushdownOptimizer
 
PreOrderDepthFirstWalker - Class in org.apache.pig.pen.util
 
PreOrderDepthFirstWalker(OperatorPlan) - Constructor for class org.apache.pig.pen.util.PreOrderDepthFirstWalker
 
prepareLoadFuncForReading(PigSplit) - Method in class org.apache.pig.piggybank.storage.AllLoader.AllReader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MergeJoinIndexer
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.builtin.AvroStorage
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.builtin.BinStorage
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.builtin.JsonLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.builtin.mock.Storage
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.builtin.OrcStorage
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.builtin.PigStorage
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.builtin.TextLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.impl.builtin.DefaultIndexableLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.impl.builtin.PoissonSampleLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.impl.builtin.RandomSampleLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.impl.builtin.SampleLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.impl.io.InterStorage
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.impl.io.ReadToEndLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.impl.io.TFileStorage
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.LoadFunc
Initializes LoadFunc for reading data.
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.LoadFuncWrapper
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.piggybank.storage.AllLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.piggybank.storage.CSVLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.piggybank.storage.FixedWidthLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.piggybank.storage.RegExLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.pig.piggybank.storage.XMLLoader
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.builtin.AvroStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.builtin.BinStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.builtin.JsonStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.builtin.mock.Storage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.builtin.OrcStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.builtin.PigStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.impl.io.InterStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.impl.io.TFileStorage
 
prepareToWrite(Schema) - Method in class org.apache.pig.impl.util.avro.AvroRecordWriter
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.piggybank.storage.DBStorage
Initialise the database connection and prepared statement here.
prepareToWrite(RecordWriter) - Method in class org.apache.pig.piggybank.storage.FixedWidthStorer
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.piggybank.storage.MultiStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.pig.StoreFunc
Initialize StoreFunc to write data.
prepareToWrite(RecordWriter) - Method in interface org.apache.pig.StoreFuncInterface
Initialize StoreFuncInterface to write data.
prepareToWrite(RecordWriter) - Method in class org.apache.pig.StoreFuncWrapper
 
PreprocessorContext - Class in org.apache.pig.tools.parameters
 
PreprocessorContext(int) - Constructor for class org.apache.pig.tools.parameters.PreprocessorContext
 
PreprocessorContext.CallableStreamReader - Class in org.apache.pig.tools.parameters
Slurp in an entire input stream and close it.
PRETTY_PRINT_SCHEMA_PROPERTY - Static variable in class org.apache.pig.PigServer
 
prettyPrint() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
PrimitiveEvalFunc<IN,OUT> - Class in org.apache.pig
Base class for simple Pig UDFs that are functions of primitive types IN to OUT.
PrimitiveEvalFunc() - Constructor for class org.apache.pig.PrimitiveEvalFunc
 
PrimitiveEvalFunc(Class, Class) - Constructor for class org.apache.pig.PrimitiveEvalFunc
 
print(OutputStream) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
print(OutputStream) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.XMLPhysicalPlanPrinter
 
print(PrintStream) - Method in class org.apache.pig.tools.timer.PerformanceTimer
Dump the total time, total number of starts and stops, and average run time of the timer to an output stream.
printAliases() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
printAliases() - Method in class org.apache.pig.parser.DryRunGruntParser
 
printAliases() - Method in class org.apache.pig.PigServer
Intended to be used by unit tests only.
printAliases() - Method in class org.apache.pig.tools.grunt.GruntParser
 
printClear() - Method in class org.apache.pig.parser.DryRunGruntParser
 
printClear() - Method in class org.apache.pig.tools.grunt.GruntParser
 
printHelp() - Method in class org.apache.pig.parser.DryRunGruntParser
 
printHelp() - Method in class org.apache.pig.tools.grunt.GruntParser
 
printHistory(boolean) - Method in class org.apache.pig.PigServer
 
printProperties() - Static method in class org.apache.pig.Main
 
printSimple(Operator, LogicalPlan, Map<Operator, DataBag>) - Static method in class org.apache.pig.pen.util.DisplayExamples
 
printTabular(LogicalPlan, Map<Operator, DataBag>, Map<LOForEach, Map<LogicalRelationalOperator, DataBag>>) - Static method in class org.apache.pig.pen.util.DisplayExamples
 
proactive_spill(Comparator<Tuple>) - Method in class org.apache.pig.data.InternalSortedBag
 
proactive_spill(Comparator<Tuple>) - Method in class org.apache.pig.data.SortedSpillBag
Sort contents of mContents and write them to disk
processCat(String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processCat(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processCD(String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processCD(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processCopy(String, String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processCopy(String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processCopyFromLocal(String, String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processCopyFromLocal(String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processCopyToLocal(String, String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processCopyToLocal(String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processDeclare(String, String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processDeclare(String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processDefault(String, String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processDefault(String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processDescribe(String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processDescribe(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processDump(String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processDump(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processError(String) - Method in class org.apache.pig.backend.hadoop.streaming.HadoopExecutableManager
 
processError(String) - Method in class org.apache.pig.impl.streaming.ExecutableManager
Workhorse to process the stderr stream of the managed process.
processExplain(String, String, boolean, String, String, List<String>, List<String>) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processExplain(String, String, boolean, String, String, List<String>, List<String>) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processExplain(String, String, boolean, String, String, List<String>, List<String>, boolean) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processFsCommand(String[]) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processFsCommand(String[]) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processHistory(boolean) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processHistory(boolean) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processIllustrate(String, String, String, List<String>, List<String>) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processIllustrate(String, String, String, List<String>, List<String>) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processingPlan - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
processingPlan - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
processInput() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
processInput() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
processInput() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
A generic method for parsing input that either returns the attached input if it exists or fetches it from its predecessor.
processInputBag() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
processKill(String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processKill(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
ProcessKiller() - Constructor for class org.apache.pig.impl.builtin.StreamingUDF.ProcessKiller
 
processLoadAndParallelism(TezOperPlan, PigContext) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.TezLauncher
 
processLS(String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processLS(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processMkdir(String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processMkdir(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processMove(String, String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processMove(String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processMRSettings(Configuration, Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.MRToTezHelper
Process the mapreduce configuration settings and - copy as is the still required ones (like those used by FileInputFormat/FileOutputFormat) - convert and set equivalent tez runtime settings - handle compression related settings
processOnePackageOutput(Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
 
processOnePackageOutput(Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
 
processOrdLine(String, String) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
This method generates value for the specified key by performing substitution if needed within the value first.
processOrdLine(String, String, Boolean) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
This method generates value for the specified key by performing substitution if needed within the value first.
processPig(String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processPig(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
processPWD() - Method in class org.apache.pig.parser.DryRunGruntParser
 
processPWD() - Method in class org.apache.pig.tools.grunt.GruntParser
 
processRegister(String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processRegister(String, String, String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processRegister(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processRegister(String, String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processRemove(String, String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processRemove(String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processScript(String, boolean, List<String>, List<String>) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processScript(String, boolean, List<String>, List<String>) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processSet(String, String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processSet() - Method in class org.apache.pig.parser.DryRunGruntParser
 
processSet(String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processSet() - Method in class org.apache.pig.tools.grunt.GruntParser
 
processShCommand(String[]) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processShCommand(String[]) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processShellCmd(String, String) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
This method generates parameter value by running specified command
processShellCmd(String, String, Boolean) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
This method generates parameter value by running specified command
processSQLCommand(String) - Method in class org.apache.pig.parser.DryRunGruntParser
 
processSQLCommand(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
progress() - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchProgressableReporter
 
progress(String) - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchProgressableReporter
 
progress() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.IllustrateDummyReporter
 
progress() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRTaskContext
 
progress() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase.IllustratorContext
 
progress() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl
 
progress() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ProgressableReporter
 
progress(String) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ProgressableReporter
 
progress() - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.PigProgressable
Report progress.
progress(String) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.PigProgressable
Report progress with a message.
progress() - Method in class org.apache.pig.backend.hadoop.executionengine.TaskContext
 
progress() - Method in class org.apache.pig.EvalFunc
Utility method to allow UDF to report progress.
progress() - Method in class org.apache.pig.tools.pigstats.PigStatusReporter
 
PROGRESS_KEY - Static variable in interface org.apache.pig.backend.executionengine.ExecJob
 
PROGRESS_NOTIFICATION_LISTENER_ARG_KEY - Static variable in class org.apache.pig.Main
 
PROGRESS_NOTIFICATION_LISTENER_KEY - Static variable in class org.apache.pig.Main
 
ProgressableReporter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
ProgressableReporter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ProgressableReporter
 
ProgressableReporter(TaskAttemptContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ProgressableReporter
 
progressUpdatedNotification(String, int) - Method in interface org.apache.pig.tools.pigstats.PigProgressNotificationListener
Invoked to update the execution progress.
ProjectExpression - Class in org.apache.pig.newplan.logical.expression
Projection of columns in an expression.
ProjectExpression(OperatorPlan, int, int, LogicalRelationalOperator) - Constructor for class org.apache.pig.newplan.logical.expression.ProjectExpression
Adds projection to the plan.
ProjectExpression(OperatorPlan, int, String, Operator, LogicalRelationalOperator) - Constructor for class org.apache.pig.newplan.logical.expression.ProjectExpression
Adds projection to the plan.
ProjectExpression(OperatorPlan, int, LogicalRelationalOperator) - Constructor for class org.apache.pig.newplan.logical.expression.ProjectExpression
Constructor for range projection Adds projection to the plan.
ProjectExpression(ProjectExpression, OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.expression.ProjectExpression
like a copy constructor, but with a plan argument
ProjectFinder(OperatorPlan, PlanWalker) - Constructor for class org.apache.pig.newplan.logical.visitor.ScalarVariableValidator.ProjectFinder
 
PROJECTION_ID - Static variable in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
ProjectionFinder(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.optimizer.ProjectionPatcher.ProjectionFinder
 
ProjectionMap - Class in org.apache.pig.impl.plan
A struct detailing how a projection is altered by an operator.
ProjectionMap(boolean) - Constructor for class org.apache.pig.impl.plan.ProjectionMap
 
ProjectionMap(MultiMap<Integer, ProjectionMap.Column>, List<Pair<Integer, Integer>>, List<Integer>) - Constructor for class org.apache.pig.impl.plan.ProjectionMap
 
ProjectionMap.Column - Class in org.apache.pig.impl.plan
A wrapper for projection map columns to contain the input number, input column.
ProjectionPatcher - Class in org.apache.pig.newplan.logical.optimizer
A PlanTransformListener that will patch up references in projections.
ProjectionPatcher() - Constructor for class org.apache.pig.newplan.logical.optimizer.ProjectionPatcher
 
ProjectionPatcher.ProjectionFinder - Class in org.apache.pig.newplan.logical.optimizer
 
ProjectStarExpander - Class in org.apache.pig.newplan.logical.visitor
A visitor to walk operators that contain a nested plan and translate project( * ) operators to a list of projection operators, i.e., project( * ) -> project(0), project(1), ...
ProjectStarExpander(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.ProjectStarExpander
 
ProjectStarExpanderUtil - Class in org.apache.pig.newplan.logical.visitor
Util function(s) for project-(star/range) expansion
ProjectStarExpanderUtil() - Constructor for class org.apache.pig.newplan.logical.visitor.ProjectStarExpanderUtil
 
ProjStarInUdfExpander - Class in org.apache.pig.newplan.logical.visitor
Expand project-star or project-range when used as udf argument.
ProjStarInUdfExpander(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.ProjStarInUdfExpander
 
prompt() - Method in class org.apache.pig.parser.DryRunGruntParser
 
prompt() - Method in class org.apache.pig.tools.grunt.GruntParser
 
PROP_CACHEDBAG_MEMUSAGE - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
use PigConfiguration.PIG_CACHEDBAG_MEMUSAGE instead. Will be removed in Pig 0.16
PROP_EXEC_MAP_PARTAGG - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
use PigConfiguration.PIG_EXEC_MAP_PARTAGG instead. Will be removed in Pig 0.16
PROP_NO_COMBINER - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
use #PROP_NO_COMBINER1 instead. Will be removed in Pig 0.16
PropertiesUtil - Class in org.apache.pig.impl.util
 
PropertiesUtil() - Constructor for class org.apache.pig.impl.util.PropertiesUtil
 
ps - Variable in class org.apache.pig.impl.plan.PlanDumper
 
ps - Variable in class org.apache.pig.newplan.PlanDumper
 
ptypes - Static variable in class org.apache.pig.piggybank.storage.hiverc.HiveRCSchemaUtil
Regex to filter out column types
pushAfter(E, E, int) - Method in class org.apache.pig.impl.plan.OperatorPlan
Push one operator after another.
pushBefore(E, E, int) - Method in class org.apache.pig.impl.plan.OperatorPlan
Push one operator in front of another.
pushdownExpr - Variable in class org.apache.pig.newplan.FilterExtractor
 
pushdownExprPlan - Variable in class org.apache.pig.newplan.FilterExtractor
Plan that can be pushed down
PushDownForEachFlatten - Class in org.apache.pig.newplan.logical.rules
It's generally a good idea to do flattens as late as possible as they tend to generate more rows (and so more I/O).
PushDownForEachFlatten(String) - Constructor for class org.apache.pig.newplan.logical.rules.PushDownForEachFlatten
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in class org.apache.pig.builtin.AvroStorage
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in class org.apache.pig.builtin.OrcStorage
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in class org.apache.pig.builtin.ParquetLoader
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in class org.apache.pig.builtin.PigStorage
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in interface org.apache.pig.LoadPushDown
Indicate to the loader fields that will be needed.
pushProjection(LoadPushDown.RequiredFieldList) - Method in class org.apache.pig.piggybank.storage.AllLoader
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in class org.apache.pig.piggybank.storage.CSVLoader
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in class org.apache.pig.piggybank.storage.FixedWidthLoader
 
pushProjection(LoadPushDown.RequiredFieldList) - Method in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
PushUpFilter - Class in org.apache.pig.newplan.logical.rules
 
PushUpFilter(String) - Constructor for class org.apache.pig.newplan.logical.rules.PushUpFilter
 
PushUpFilter.PushUpFilterTransformer - Class in org.apache.pig.newplan.logical.rules
 
PushUpFilterTransformer() - Constructor for class org.apache.pig.newplan.logical.rules.PushUpFilter.PushUpFilterTransformer
 
pushWalker(PlanWalker<O, P>) - Method in class org.apache.pig.impl.plan.PlanVisitor
Push the current walker onto the stack of saved walkers and begin using the newly passed walker as the current walker.
pushWalker(PlanWalker) - Method in class org.apache.pig.newplan.PlanVisitor
Push the current walker onto the stack of saved walkers and begin using the newly passed walker as the current walker.
put(K, Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.CountingMap
 
put(Object, ArrayList<Tuple>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin.TupleToMapKey
 
put(CharSequence, Object) - Method in class org.apache.pig.impl.util.avro.AvroMapWrapper
 
put(K, V) - Method in class org.apache.pig.impl.util.MultiMap
Add an element to the map.
put(K, Collection<V>) - Method in class org.apache.pig.impl.util.MultiMap
Add a key to the map with a collection of elements.
put(Operator, Operator, int) - Method in class org.apache.pig.newplan.PlanEdge
Add an element to the map.
putAll(Map<? extends CharSequence, ? extends Object>) - Method in class org.apache.pig.impl.util.avro.AvroMapWrapper
 
putField(OutputStream, Object) - Static method in class org.apache.pig.impl.util.StorageUtil
 
putField(OutputStream, Object, boolean) - Static method in class org.apache.pig.impl.util.StorageUtil
 
putField(OutputStream, Object, StreamingDelimiters, boolean) - Static method in class org.apache.pig.impl.util.StorageUtil
Serialize an object to an OutputStream in the field-delimited form.
putField(OutputStream, Object) - Method in class org.apache.pig.piggybank.storage.HiveColumnarStorage
 
putNext(Tuple) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
putNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.StoreFuncDecorator
Call StoreFunc#putNext(Tuple) and handle errors
putNext(Tuple) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
putNext(Tuple) - Method in class org.apache.pig.builtin.AvroStorage
 
putNext(Tuple) - Method in class org.apache.pig.builtin.BinStorage
 
putNext(Tuple) - Method in class org.apache.pig.builtin.JsonStorage
 
putNext(Tuple) - Method in class org.apache.pig.builtin.mock.Storage
 
putNext(Tuple) - Method in class org.apache.pig.builtin.OrcStorage
 
putNext(Tuple) - Method in class org.apache.pig.builtin.PigStorage
 
putNext(Tuple) - Method in class org.apache.pig.impl.io.InterStorage
 
putNext(Tuple) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
putNext(Tuple) - Method in class org.apache.pig.impl.io.TFileStorage
 
putNext(Tuple) - Method in class org.apache.pig.impl.streaming.InputHandler
Send the given input Tuple to the managed executable.
putNext(Tuple) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
putNext(Tuple) - Method in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
putNext(Tuple) - Method in class org.apache.pig.piggybank.storage.DBStorage
Write the tuple to Database directly here.
putNext(Tuple) - Method in class org.apache.pig.piggybank.storage.FixedWidthStorer
 
putNext(Tuple) - Method in class org.apache.pig.piggybank.storage.HiveColumnarStorage
 
putNext(Tuple) - Method in class org.apache.pig.piggybank.storage.MultiStorage
 
putNext(Tuple) - Method in class org.apache.pig.StoreFunc
Write a tuple to the data store.
putNext(Tuple) - Method in interface org.apache.pig.StoreFuncInterface
Write a tuple to the data store.
putNext(Tuple) - Method in class org.apache.pig.StoreFuncWrapper
 
PythonScriptEngine - Class in org.apache.pig.scripting.streaming.python
 
PythonScriptEngine() - Constructor for class org.apache.pig.scripting.streaming.python.PythonScriptEngine
 
pythonToPig(PyObject) - Static method in class org.apache.pig.scripting.jython.JythonUtils
 

Q

quantiles - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
QUANTILES_LIST - Static variable in class org.apache.pig.impl.builtin.FindQuantiles
 
QueryParserDriver - Class in org.apache.pig.parser
 
QueryParserDriver(PigContext, String, Map<String, String>) - Constructor for class org.apache.pig.parser.QueryParserDriver
 
QueryParserFileStream - Class in org.apache.pig.parser
Pig's implementation class of file stream, used to make ANTLR case insensitive while preserving case.
QueryParserFileStream(String) - Constructor for class org.apache.pig.parser.QueryParserFileStream
 
QueryParserFileStream(String, String) - Constructor for class org.apache.pig.parser.QueryParserFileStream
 
QueryParserStreamUtil - Class in org.apache.pig.parser
 
QueryParserStreamUtil() - Constructor for class org.apache.pig.parser.QueryParserStreamUtil
 
QueryParserStringStream - Class in org.apache.pig.parser
Pig's Implementation class for String stream, used to make ANTLR case insensitive while preserving case.
QueryParserStringStream(String, String) - Constructor for class org.apache.pig.parser.QueryParserStringStream
 
QueryParserUtils - Class in org.apache.pig.parser
 
QueryParserUtils() - Constructor for class org.apache.pig.parser.QueryParserUtils
 
quit() - Method in class org.apache.pig.parser.DryRunGruntParser
 
quit() - Method in class org.apache.pig.tools.grunt.GruntParser
 

R

RANDOM - Class in org.apache.pig.builtin
Return a random double value.
RANDOM() - Constructor for class org.apache.pig.builtin.RANDOM
 
RANDOM(String) - Constructor for class org.apache.pig.builtin.RANDOM
 
RANDOM - Class in org.apache.pig.piggybank.evaluation.math
 
RANDOM() - Constructor for class org.apache.pig.piggybank.evaluation.math.RANDOM
 
RandomSampleLoader - Class in org.apache.pig.impl.builtin
A loader that samples the data.
RandomSampleLoader(String, String) - Constructor for class org.apache.pig.impl.builtin.RandomSampleLoader
Construct with a class of loader to use.
RankConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
RankConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.RankConverter
 
RAW_CAPACITY_KEY - Static variable in interface org.apache.pig.backend.datastorage.DataStorage
 
RAW_USED_KEY - Static variable in interface org.apache.pig.backend.datastorage.DataStorage
 
RDDConverter<IN,OUT,T extends PhysicalOperator> - Interface in org.apache.pig.backend.hadoop.executionengine.spark.converter
Given an RDD and a PhysicalOperater, and implementation of this class can convert the RDD to another RDD.
read() - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
read(byte[]) - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
read(byte[], int, int) - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
read(DataInput, DataBag) - Static method in class org.apache.pig.data.SchemaTuple
 
read(DataInput, Map<String, Object>) - Static method in class org.apache.pig.data.SchemaTuple
 
read(DataInput, int) - Static method in class org.apache.pig.data.SchemaTuple
 
read(DataInput, long) - Static method in class org.apache.pig.data.SchemaTuple
 
read(DataInput, float) - Static method in class org.apache.pig.data.SchemaTuple
 
read(DataInput, double) - Static method in class org.apache.pig.data.SchemaTuple
 
read(DataInput, DateTime) - Static method in class org.apache.pig.data.SchemaTuple
 
read(DataInput, BigDecimal) - Static method in class org.apache.pig.data.SchemaTuple
 
read(DataInput, BigInteger) - Static method in class org.apache.pig.data.SchemaTuple
 
read(DataInput, String) - Static method in class org.apache.pig.data.SchemaTuple
 
read(DataInput, byte[]) - Static method in class org.apache.pig.data.SchemaTuple
 
read() - Method in class org.apache.pig.impl.io.BufferedPositionedInputStream
 
read(byte[], int, int) - Method in class org.apache.pig.impl.io.BufferedPositionedInputStream
 
read() - Method in class org.apache.pig.impl.io.FileLocalizer.DataStorageInputStreamIterator
 
read(byte[], int, int) - Method in class org.apache.pig.impl.io.FileLocalizer.DataStorageInputStreamIterator
 
read(byte[]) - Method in class org.apache.pig.impl.io.FileLocalizer.DataStorageInputStreamIterator
 
read(byte[], int, int) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorageInputStream
 
readBooleanArray(DataInput, int) - Static method in class org.apache.pig.data.utils.SedesHelper
 
readBytes(DataInput, byte) - Static method in class org.apache.pig.data.utils.SedesHelper
 
readBytes(Object, Decoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumReader
Called to read byte arrays.
readChararray(DataInput, byte) - Static method in class org.apache.pig.data.utils.SedesHelper
 
readDatum(DataInput) - Method in class org.apache.pig.data.BinInterSedes
 
readDatum(DataInput, byte) - Method in class org.apache.pig.data.BinInterSedes
Expects binInterSedes data types (NOT DataType types!)
readDatum(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
readDatum(DataInput, byte) - Static method in class org.apache.pig.data.DataReaderWriter
 
readDatum(DataInput) - Method in interface org.apache.pig.data.InterSedes
Get the next object from DataInput in
readDatum(DataInput, byte) - Method in interface org.apache.pig.data.InterSedes
Get the next object from DataInput in of the type of type argument The type information has been read from DataInput.
reader - Variable in class org.apache.pig.builtin.JsonLoader
 
readerComparator - Variable in class org.apache.pig.piggybank.storage.IndexedStorage
Comparator used to compare key tuples.
readers - Variable in class org.apache.pig.piggybank.storage.IndexedStorage
List of record readers.
readField(byte[], int, int) - Method in class org.apache.pig.builtin.PigStorage
Read the bytes between start and end into a DataByteArray for inclusion in the return tuple.
readFields(DataInput) - Method in class org.apache.pig.backend.hadoop.BigDecimalWritable
 
readFields(DataInput) - Method in class org.apache.pig.backend.hadoop.BigIntegerWritable
 
readFields(DataInput) - Method in class org.apache.pig.backend.hadoop.DateTimeWritable
 
readFields(DataInput) - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
readFields(DataInput) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
readFields(DataInput) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
readFields(DataInput) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
readFields(DataInput) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez.EmptyWritable
 
readFields(DataInput) - Method in class org.apache.pig.backend.hadoop.hbase.TableSplitComparable
 
readFields(DataInput) - Method in class org.apache.pig.data.AccumulativeBag
 
readFields(DataInput) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
readFields(DataInput) - Method in class org.apache.pig.data.BinSedesTuple
 
readFields(DataInput) - Method in class org.apache.pig.data.DefaultAbstractBag
Read a bag from disk.
readFields(DataInput) - Method in class org.apache.pig.data.DefaultTuple
 
readFields(DataInput) - Method in class org.apache.pig.data.LimitedSortedDataBag
Read a bag from disk.
readFields(DataInput) - Method in class org.apache.pig.data.NonSpillableDataBag
Read a bag from disk.
readFields(DataInput) - Method in class org.apache.pig.data.ReadOnceBag
 
readFields(DataInput) - Method in class org.apache.pig.data.SchemaTuple
 
readFields(DataInput) - Method in class org.apache.pig.data.SingleTupleBag
 
readFields(DataInput) - Method in class org.apache.pig.data.TargetedTuple
 
readFields(DataInput) - Method in class org.apache.pig.data.UnlimitedNullTuple
 
readFields(DataInput) - Method in class org.apache.pig.FileSplitComparable
 
readFields(DataInput) - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
readFields(DataInput) - Method in class org.apache.pig.impl.io.NullableTuple
 
readFields(DataInput) - Method in class org.apache.pig.impl.io.PigNullableWritable
 
readFields(DataInput) - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
readFields(DataInput) - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
readFields(DataInput) - Method in class org.apache.pig.pen.util.ExampleTuple
 
readFixed(Object, Schema, Decoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumReader
Called to read a fixed value.
readGenericTuple(DataInput, byte) - Static method in class org.apache.pig.data.utils.SedesHelper
 
ReadIndex() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Reads the next index from the index file (or null if EOF) and extracts the index fields.
ReadIndexFooter() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Reads the index footer
ReadIndexHeader() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Read index header
readLine(Charset, byte) - Method in class org.apache.pig.impl.io.BufferedPositionedInputStream
 
readLine(Text, int, int) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.IndexedStorageLineReader
Read one line from the InputStream into the given Text.
readLine(Text, int) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.IndexedStorageLineReader
Read from the InputStream into the given Text.
readLine(Text) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.IndexedStorageLineReader
Read from the InputStream into the given Text.
readMap(Object, Schema, ResolvingDecoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumReader
Called to read a map instance.
readOnce - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
ReadOnceBag - Class in org.apache.pig.data
This bag does not store the tuples in memory, but has access to an iterator typically provided by Hadoop.
ReadOnceBag() - Constructor for class org.apache.pig.data.ReadOnceBag
 
ReadOnceBag(Packager, Iterator<NullableTuple>, PigNullableWritable) - Constructor for class org.apache.pig.data.ReadOnceBag
This constructor creates a bag out of an existing iterator of tuples by taking ownership of the iterator and NOT copying the elements of the iterator.
ReadOnceBag.ReadOnceBagIterator - Class in org.apache.pig.data
 
ReadOnceBagIterator() - Constructor for class org.apache.pig.data.ReadOnceBag.ReadOnceBagIterator
 
readRecord(Object, Schema, ResolvingDecoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumReader
Called to read a record instance.
readReduceMapFromSample(TupleFactory) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezRuntimeUtil
 
ReadScalars - Class in org.apache.pig.impl.builtin
ReadScalars reads a line from a file and returns it as its value.
ReadScalars() - Constructor for class org.apache.pig.impl.builtin.ReadScalars
 
ReadScalarsTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.udf
 
ReadScalarsTez(String) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.ReadScalarsTez
 
readSignedVarInt(DataInput) - Static method in class org.apache.pig.data.utils.SedesHelper.Varint
 
readSignedVarLong(DataInput) - Static method in class org.apache.pig.data.utils.SedesHelper.Varint
 
readString(Object, Schema, Decoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumReader
Called to read strings.
ReadToEndLoader - Class in org.apache.pig.impl.io
This is wrapper Loader which wraps a real LoadFunc underneath and allows to read a file completely starting a given split (indicated by a split index which is used to look in the List returned by the underlying InputFormat's getSplits() method).
ReadToEndLoader(LoadFunc, Configuration, String, int) - Constructor for class org.apache.pig.impl.io.ReadToEndLoader
 
ReadToEndLoader(LoadFunc, Configuration, String, int, String) - Constructor for class org.apache.pig.impl.io.ReadToEndLoader
 
ReadToEndLoader(LoadFunc, Configuration, String, int[]) - Constructor for class org.apache.pig.impl.io.ReadToEndLoader
This constructor takes an array of split indexes (toReadSplitIdxs) of the splits to be read.
readTuple(DataInput, byte) - Method in class org.apache.pig.data.BinInterSedes
 
readTuple(DataInput) - Method in class org.apache.pig.data.BinInterSedes
 
readUnsignedVarInt(DataInput) - Static method in class org.apache.pig.data.utils.SedesHelper.Varint
 
readUnsignedVarLong(DataInput) - Static method in class org.apache.pig.data.utils.SedesHelper.Varint
 
receiver - Variable in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
recomputeProperties(JobConf, Properties) - Static method in class org.apache.pig.impl.util.Utils
Method to apply pig properties to JobConf (replaces properties with resulting jobConf values).
reconcile(Schema) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Reconcile this schema with another schema.
RECORD - Static variable in class org.apache.pig.piggybank.storage.avro.AvroSchema2Pig
 
RECORD_1 - Static variable in class org.apache.pig.impl.io.BinStorageRecordReader
 
RECORD_1 - Static variable in class org.apache.pig.impl.io.BinStorageRecordWriter
 
RECORD_1 - Static variable in class org.apache.pig.impl.io.InterRecordReader
 
RECORD_1 - Static variable in class org.apache.pig.impl.io.InterRecordWriter
 
RECORD_2 - Static variable in class org.apache.pig.impl.io.BinStorageRecordReader
 
RECORD_2 - Static variable in class org.apache.pig.impl.io.BinStorageRecordWriter
 
RECORD_2 - Static variable in class org.apache.pig.impl.io.InterRecordReader
 
RECORD_2 - Static variable in class org.apache.pig.impl.io.InterRecordWriter
 
RECORD_3 - Static variable in class org.apache.pig.impl.io.BinStorageRecordReader
 
RECORD_3 - Static variable in class org.apache.pig.impl.io.BinStorageRecordWriter
 
RECORD_3 - Static variable in class org.apache.pig.impl.io.InterRecordReader
 
RECORD_3 - Static variable in class org.apache.pig.impl.io.InterRecordWriter
 
RECORD_DEL - Static variable in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
RecordReaderFactory(InputSplit, TaskAttemptContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat.RecordReaderFactory
 
recoverTask(TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
reduce(PigNullableWritable, Iterable<NullableTuple>, Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.DistinctCombiner.Combine
The reduce function which removes values.
reduce(PigNullableWritable, Iterable<NullableTuple>, Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
The reduce function which packages the key and List <Tuple> into key, Bag<Tuple> after converting Hadoop type key into Pig type.
Reduce() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
 
reduce(PigNullableWritable, Iterable<NullableTuple>, Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
The reduce function which packages the key and List<Tuple> into key, Bag<Tuple> after converting Hadoop type key into Pig type.
reduce(PigNullableWritable, Iterable<NullableTuple>, Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.ReduceWithComparator
The reduce function which packages the key and List<Tuple> into key, Bag<Tuple> after converting Hadoop type key into Pig type.
Reduce() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
 
REDUCE_INPUT_RECORDS - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
 
REDUCE_MAX_ATTEMPTS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
REDUCE_OUTPUT_RECORDS - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
 
REDUCE_TASKS - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
ReduceByConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
ReduceByConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.ReduceByConverter
 
reducePlan - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
REDUCER_DEFAULT_PARALLELISM - Static variable in class org.apache.pig.impl.PigImplConstants
Parallelism for the reducer
REDUCER_ESTIMATED_PARALLELISM - Static variable in class org.apache.pig.impl.PigImplConstants
 
REDUCER_NEW_API - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
REDUCER_REQUESTED_PARALLELISM - Static variable in class org.apache.pig.impl.PigImplConstants
 
reducerMap - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SkewedPartitioner
 
reducerMap - Variable in class org.apache.pig.impl.builtin.IsFirstReduceOfKey
 
reduceStores - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
 
ReduceWithComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.ReduceWithComparator
 
reference(Tuple) - Method in class org.apache.pig.data.AbstractTuple
 
reference(Tuple) - Method in class org.apache.pig.data.SchemaTuple
 
reference(Tuple) - Method in class org.apache.pig.data.TargetedTuple
 
reference(Tuple) - Method in interface org.apache.pig.data.Tuple
Deprecated.
reference(Tuple) - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
reference(Tuple) - Method in class org.apache.pig.pen.util.ExampleTuple
 
regenerateProjectionMap() - Method in class org.apache.pig.impl.plan.Operator
Regenerate the projection map by unsetting and getting the projection map
REGEX_EXTRACT - Class in org.apache.pig.builtin
Syntax: String RegexExtract(String expression, String regex, int match_index). Input: expression-source string. regex-regular expression. match_index-index of the group to extract. Output: extracted group, if fail, return null. Matching strategy: Try to only match the first sequence by using Matcher.find() instead of Matcher.matches() (default useMatches=false). DEFINE NON_GREEDY_EXTRACT REGEX_EXTRACT('true');
REGEX_EXTRACT() - Constructor for class org.apache.pig.builtin.REGEX_EXTRACT
 
REGEX_EXTRACT(String) - Constructor for class org.apache.pig.builtin.REGEX_EXTRACT
 
REGEX_EXTRACT_ALL - Class in org.apache.pig.builtin
Syntax: String RegexExtractAll(String expression, String regex). Input: expression-source string. regex-regular expression. Output: A tuple of matched strings. Matching strategy: Trying to match the entire input by using Matcher.matches() instead of Matcher.find() (default useMatches=true). DEFINE GREEDY_EXTRACT REGEX_EXTRACT_ALL('false');
REGEX_EXTRACT_ALL() - Constructor for class org.apache.pig.builtin.REGEX_EXTRACT_ALL
 
REGEX_EXTRACT_ALL(String) - Constructor for class org.apache.pig.builtin.REGEX_EXTRACT_ALL
 
REGEX_SEARCH - Class in org.apache.pig.builtin
Search and find all matched characters in a string with a given regular expression.
REGEX_SEARCH() - Constructor for class org.apache.pig.builtin.REGEX_SEARCH
 
RegexExpression - Class in org.apache.pig.newplan.logical.expression
Regex Operator
RegexExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.RegexExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
RegexExtract - Class in org.apache.pig.piggybank.evaluation.string
Deprecated.
RegexExtract() - Constructor for class org.apache.pig.piggybank.evaluation.string.RegexExtract
Deprecated.
 
RegexExtractAll - Class in org.apache.pig.piggybank.evaluation.string
Deprecated.
RegexExtractAll() - Constructor for class org.apache.pig.piggybank.evaluation.string.RegexExtractAll
Deprecated.
 
RegexImpl - Interface in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex
 
RegexInit - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex
 
RegexInit(PORegexp) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex.RegexInit
 
RegExLoader - Class in org.apache.pig.piggybank.storage
RegExLoader is an abstract class used to parse logs based on a regular expression.
RegExLoader() - Constructor for class org.apache.pig.piggybank.storage.RegExLoader
 
RegexMatch - Class in org.apache.pig.piggybank.evaluation.string
Syntax: int RegexMatch(String expression, String regex). Output: return 1 if expression contains regex, 0 otherwise.
RegexMatch() - Constructor for class org.apache.pig.piggybank.evaluation.string.RegexMatch
 
registerBag(DataBag) - Method in class org.apache.pig.data.BagFactory
Deprecated.
As of Pig 0.11, bags register with the SpillableMemoryManager themselves. Register a bag with the SpillableMemoryManager. If the bags created by an implementation of BagFactory are managed by the SpillableMemoryManager then this method should be called each time a new bag is created.
registerCode(String, String, String) - Method in class org.apache.pig.PigServer
Universal Scripting Language Support, see PIG-928
registerForStaticDataCleanup(Class<?>) - Method in class org.apache.pig.JVMReuseManager
 
registerFunction(String, FuncSpec) - Method in class org.apache.pig.impl.PigContext
Defines an alias for the given function spec.
registerFunction(String, FuncSpec) - Method in class org.apache.pig.PigServer
Defines an alias for the given function spec.
registerFunctions(String, String, PigContext) - Method in class org.apache.pig.scripting.groovy.GroovyScriptEngine
 
registerFunctions(String, String, PigContext) - Method in class org.apache.pig.scripting.jruby.JrubyScriptEngine
Evaluates the script containing ruby udfs to determine what udfs are defined as well as what libaries and other external resources are necessary.
registerFunctions(String, String, PigContext) - Method in class org.apache.pig.scripting.js.JsScriptEngine
 
registerFunctions(String, String, PigContext) - Method in class org.apache.pig.scripting.jython.JythonScriptEngine
 
registerFunctions(String, String, PigContext) - Method in class org.apache.pig.scripting.ScriptEngine
Registers scripting language functions as Pig functions with given namespace
registerFunctions(String, String, PigContext) - Method in class org.apache.pig.scripting.streaming.python.PythonScriptEngine
 
registerJar(String) - Method in class org.apache.pig.PigServer
Registers a jar file.
registerJar(String) - Static method in class org.apache.pig.scripting.js.JSPig
See Pig
registerJar(String) - Static method in class org.apache.pig.scripting.Pig
Register a jar for use in Pig.
registerListener(PigProgressNotificationListener) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
registerListener(PigProgressNotificationListener) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState
 
registerNoRun(String, Map<String, String>, List<String>) - Method in class org.apache.pig.tools.ToolsPigServer
Register a script without running it.
registerOpt(char, String, CmdLineParser.ValueExpected) - Method in class org.apache.pig.tools.cmdline.CmdLineParser
Register a command line option.
registerOutputLocation(String, String) - Method in class org.apache.pig.scripting.ScriptingOutputCapturer
 
registerQuery(String, int) - Method in class org.apache.pig.PigServer
Register a query with the Pig runtime.
registerQuery(String) - Method in class org.apache.pig.PigServer
Register a query with the Pig runtime.
RegisterResolver - Class in org.apache.pig.parser
 
RegisterResolver(PigServer) - Constructor for class org.apache.pig.parser.RegisterResolver
 
registerScript(InputStream) - Method in class org.apache.pig.PigServer
Register a pig script from InputStream source which is more general and extensible the pig script can be from local file, then you can use FileInputStream.
registerScript(InputStream, Map<String, String>) - Method in class org.apache.pig.PigServer
Register a pig script from InputStream source which is more general and extensible the pig script can be from local file, then you can use FileInputStream.
registerScript(InputStream, List<String>) - Method in class org.apache.pig.PigServer
Register a pig script from InputStream source which is more general and extensible the pig script can be from local file, then you can use FileInputStream.
registerScript(InputStream, Map<String, String>, List<String>) - Method in class org.apache.pig.PigServer
Register a pig script from InputStream.
The pig script can be from local file, then you can use FileInputStream.
registerScript(String) - Method in class org.apache.pig.PigServer
Register a query with the Pig runtime.
registerScript(String, Map<String, String>) - Method in class org.apache.pig.PigServer
Register a pig script file.
registerScript(String, List<String>) - Method in class org.apache.pig.PigServer
Register a pig script file.
registerScript(String, Map<String, String>, List<String>) - Method in class org.apache.pig.PigServer
Register a pig script file.
registerSpillable(Spillable) - Method in class org.apache.pig.impl.util.SpillableMemoryManager
Register a spillable to be tracked.
registerStreamCmd(String, StreamingCommand) - Method in class org.apache.pig.impl.PigContext
Defines an alias for the given streaming command.
registerStreamingCommand(String, StreamingCommand) - Method in class org.apache.pig.PigServer
Defines an alias for the given streaming command.
registerToGenerateIfPossible(Schema, boolean, SchemaTupleClassGenerator.GenContext) - Static method in class org.apache.pig.data.SchemaTupleFrontend
This method "registers" a Schema to be generated.
registerUDF(String, String) - Static method in class org.apache.pig.scripting.js.JSPig
See Pig
registerUDF(String, String) - Static method in class org.apache.pig.scripting.Pig
Register scripting UDFs for use in Pig.
reIndex(int) - Method in class org.apache.pig.impl.plan.RequiredFields
Set the index of all fields to i
relativeToAbsolutePath(String, Path) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
relativeToAbsolutePath(String, Path) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
relativeToAbsolutePath(String, Path) - Method in class org.apache.pig.builtin.mock.Storage
 
relativeToAbsolutePath(String, Path) - Method in class org.apache.pig.impl.builtin.SampleLoader
 
relativeToAbsolutePath(String, Path) - Method in class org.apache.pig.LoadFunc
This method is called by the Pig runtime in the front end to convert the input location to an absolute path if the location is relative.
relativeToAbsolutePath(String, Path) - Method in class org.apache.pig.LoadFuncWrapper
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.builtin.AvroStorage
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.builtin.BinStorage
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.builtin.mock.Storage
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.builtin.OrcStorage
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.builtin.PigStorage
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.impl.io.InterStorage
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.impl.io.TFileStorage
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.StoreFunc
This method is called by the Pig runtime in the front end to convert the output location to an absolute path if the location is relative.
relToAbsPathForStoreLocation(String, Path) - Method in interface org.apache.pig.StoreFuncInterface
This method is called by the Pig runtime in the front end to convert the output location to an absolute path if the location is relative.
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.pig.StoreFuncWrapper
 
REMOTE_ENVIRONMENT - Static variable in exception org.apache.pig.PigException
 
remove() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl.IllustratorValueIterator
 
remove(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
remove(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperPlan
 
remove() - Method in class org.apache.pig.data.ReadOnceBag.ReadOnceBagIterator
 
remove(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Remove an operator from the plan.
remove(Object) - Method in class org.apache.pig.impl.util.avro.AvroMapWrapper
 
remove(Object) - Method in class org.apache.pig.impl.util.IdentityHashSet
 
remove(K, V) - Method in class org.apache.pig.impl.util.MultiMap
Remove one value from an existing key.
remove(Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
Remove an operator from the plan.
remove(Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
Remove an operator from the plan.
remove(Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
remove() - Method in class org.apache.pig.scripting.groovy.GroovyUtils.DataBagGroovyIterator
 
removeAll(Collection<?>) - Method in class org.apache.pig.impl.util.IdentityHashSet
 
removeAndReconnect(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Remove a node in a way that connects the node's predecessor (if any) with the node's successor (if any).
removeAndReconnect(Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
 
removeAndReconnect(Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
This method remove a node operatorToRemove.
removeAndReconnect(Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
removeAndReconnectMultiSucc(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Remove a node in a way that connects the node's predecessor (if any) with the node's successors (if any).
removeAnnotation(String) - Method in class org.apache.pig.newplan.Operator
Remove an annotation
removeFilter(POFilter, PhysicalPlan) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.NoopFilterRemoverUtil
 
removeInput(OperatorKey) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
removeKey(K) - Method in class org.apache.pig.impl.util.MultiMap
Remove all the values associated with the given key
removeOutputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
removePlan(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
Removes plan from the nested input plan list
removeQuotes(String) - Static method in class org.apache.pig.parser.QueryParserUtils
 
removeSimpleUnion(Schema) - Static method in class org.apache.pig.impl.util.avro.AvroStorageSchemaConversionUtilities
Given an input schema that is a union of an avro schema and null (or just a union with one type), return the avro schema.
removeSoftLink(E, E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Remove an soft edge
removeSoftLink(Operator, Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
Remove an soft edge
removeSoftLink(Operator, Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
Remove an soft edge
removeSoftLink(Operator, Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
removeVertexGroupStore(OperatorKey) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
removeWithPosition(Operator, Operator) - Method in class org.apache.pig.newplan.PlanEdge
Remove one value from an existing key and return which position in the arraylist the value was at..
rename(ElementDescriptor) - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
Changes the name of an entity in the Data Storage
rename(ElementDescriptor) - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
rename(String, String) - Method in class org.apache.pig.impl.PigContext
 
renameFile(String, String) - Method in class org.apache.pig.PigServer
Rename a file.
replace(PhysicalOperator, PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
REPLACE - Class in org.apache.pig.builtin
REPLACE implements eval function to replace part of a string.
REPLACE() - Constructor for class org.apache.pig.builtin.REPLACE
 
replace(E, E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Replace an existing node in the graph with a new node.
replace(Operator, Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
 
replace(Operator, Operator) - Method in interface org.apache.pig.newplan.OperatorPlan
This method replace the oldOperator with the newOperator, make all connection to the new operator in the place of old operator
replace(Operator, Operator) - Method in class org.apache.pig.newplan.OperatorSubPlan
 
REPLACE - Class in org.apache.pig.piggybank.evaluation.string
Deprecated.
REPLACE() - Constructor for class org.apache.pig.piggybank.evaluation.string.REPLACE
Deprecated.
 
REPLACE_MULTI - Class in org.apache.pig.piggybank.evaluation.string
REPLACE_MULTI implements eval function to replace all occurrences of search keys with replacement values.
REPLACE_MULTI() - Constructor for class org.apache.pig.piggybank.evaluation.string.REPLACE_MULTI
 
replaceConfigForLocalMode(Configuration) - Static method in class org.apache.pig.backend.hadoop.datastorage.ConfigurationUtil
 
replaceInput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBloomFilterRearrangeTez
 
replaceInput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
replaceInput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POFRJoinTez
 
replaceInput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POIdentityInOutTez
 
replaceInput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.PORankTez
 
replaceInput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffledValueInputTez
 
replaceInput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffleTezLoad
 
replaceInput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POSimpleTezLoad
 
replaceInput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueInputTez
 
replaceInput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.udf.ReadScalarsTez
 
replaceInput(String, String) - Method in interface org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezInput
 
replaceInput(TezOperator, String, String) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
replaceOutput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
replaceOutput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
replaceOutput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterTez
 
replaceOutput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
replaceOutput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POStoreTez
 
replaceOutput(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
replaceOutput(String, String) - Method in interface org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezOutput
 
replaceOutput(TezOperator, String, String) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
replFiles - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
replicates - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.AddForEach.AddForEachTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.ColumnMapKeyPrune.ColumnMapKeyPruneTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneHelper
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.ConstantCalculator.ConstantCalculatorTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.FilterAboveForeach.FilterAboveForEachTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.GroupByConstParallelSetter.GroupAllParallelSetterTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.LimitOptimizer.OptimizeLimitTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.MergeFilter.MergeFilterTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.MergeForEach.MergeForEachTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.NestedLimitOptimizer.OptimizeNestedLimitTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.PartitionFilterOptimizer.PartitionFilterPushDownTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.PushUpFilter.PushUpFilterTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.SplitFilter.SplitFilterTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.logical.rules.TypeCastInserter.TypeCastInserterTransformer
 
reportChanges() - Method in class org.apache.pig.newplan.optimizer.Transformer
Report what parts of the tree were transformed.
reporter - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
reporter - Variable in class org.apache.pig.ComparisonFunc
Deprecated.
 
reporter - Variable in class org.apache.pig.EvalFunc
Reporter to send heartbeats to Hadoop.
reportProgress() - Method in class org.apache.pig.data.DefaultAbstractBag
Report progress to HDFS.
reportProgress() - Method in class org.apache.pig.data.LimitedSortedDataBag
Report progress to HDFS.
reportProgress() - Method in class org.apache.pig.data.NonSpillableDataBag
Report progress to HDFS.
requestedParallelism - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
requestedParallelism - Variable in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
requestedParallelism - Variable in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
REQUIRED_MAPKEYS - Static variable in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper
 
REQUIREDCOLS - Static variable in class org.apache.pig.newplan.logical.rules.ColumnPruneHelper
 
RequiredField() - Constructor for class org.apache.pig.LoadPushDown.RequiredField
 
RequiredField(String, int, List<LoadPushDown.RequiredField>, byte) - Constructor for class org.apache.pig.LoadPushDown.RequiredField
 
requiredFieldList - Variable in class org.apache.pig.builtin.AvroStorage
List of required fields passed by pig in a push down projection.
RequiredFieldList(List<LoadPushDown.RequiredField>) - Constructor for class org.apache.pig.LoadPushDown.RequiredFieldList
Set the list of required fields.
RequiredFieldList() - Constructor for class org.apache.pig.LoadPushDown.RequiredFieldList
 
RequiredFieldResponse(boolean) - Constructor for class org.apache.pig.LoadPushDown.RequiredFieldResponse
 
RequiredFields - Class in org.apache.pig.impl.plan
A struct detailing how a projection is altered by an operator.
RequiredFields(boolean) - Constructor for class org.apache.pig.impl.plan.RequiredFields
 
RequiredFields(boolean, boolean) - Constructor for class org.apache.pig.impl.plan.RequiredFields
 
RequiredFields(List<Pair<Integer, Integer>>) - Constructor for class org.apache.pig.impl.plan.RequiredFields
 
res - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
reset() - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
reset() - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
Resets the state after a launch
reset() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
Resets the state
reset() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl.IllustratorValueIterator
 
reset() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORelationToExprProject
 
reset() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
Reset internal state in an operator.
reset() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
reset() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
reset() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
reset() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
reset() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
reset() - Static method in class org.apache.pig.data.SchemaTupleBackend
 
reset() - Static method in class org.apache.pig.data.SchemaTupleFrontend
This allows the frontend/backend process to be repeated if on the same JVM (as in testing).
reset(String) - Static method in class org.apache.pig.impl.plan.NodeIdGenerator
Reset the given scope IDs to 0 for the current Thread.
reset() - Static method in class org.apache.pig.impl.plan.NodeIdGenerator
Reset all scope IDs to 0 for the current Thread.
reset() - Method in class org.apache.pig.impl.util.UDFContext
 
resetBackupStore() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl.IllustratorValueIterator
 
resetData(PigServer) - Static method in class org.apache.pig.builtin.mock.Storage
reset the store and get the Data object to access it
resetData(PigContext) - Static method in class org.apache.pig.builtin.mock.Storage
reset the store and get the Data object to access it
resetFieldSchema() - Method in class org.apache.pig.newplan.logical.expression.LogicalExpression
 
resetGlobalClassIdentifier() - Static method in class org.apache.pig.data.SchemaTupleClassGenerator
 
resetGroupType() - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
 
resetJoinType() - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
resetLocalCounter() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
Initialization step into the POCounter is to set up local counter to 1.
resetNextUid() - Static method in class org.apache.pig.newplan.logical.expression.LogicalExpression
 
resetOpMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
ResetProjectionAttachedRelationalOpVisitor - Class in org.apache.pig.newplan.logical.visitor
 
ResetProjectionAttachedRelationalOpVisitor(LogicalExpressionPlan, LogicalRelationalOperator) - Constructor for class org.apache.pig.newplan.logical.visitor.ResetProjectionAttachedRelationalOpVisitor
 
resetSchema() - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
resetSchema() - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
Reset the schema to null so that the next time getSchema is called the schema will be regenerated from scratch.
resetSchema() - Method in class org.apache.pig.newplan.logical.relational.LOInnerLoad
 
resetScope() - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainer
 
resetScope() - Static method in class org.apache.pig.PigServer
 
resetSeedUniquifier() - Static method in class org.apache.pig.builtin.RANDOM
 
resetSelf() - Static method in class org.apache.pig.data.BagFactory
Provided for testing purposes only.
resetSelf() - Static method in class org.apache.pig.data.TupleFactory
Provided for testing purposes only.
resetUDFContextForThreadReuse() - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigOutputFormatTez
 
resetUid() - Method in class org.apache.pig.newplan.logical.expression.LogicalExpression
Erase all cached uid, regenerate uid when we regenerating schema.
resetUid() - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
 
resetUid() - Method in class org.apache.pig.newplan.logical.relational.LOCube
 
resetUid() - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
resetUid() - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
Erase all cached uid, regenerate uid when we regenerating schema.
resetUid() - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
Rest uid of this fieldschema and inner schema
resetUid() - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Reset uids of all fieldschema that the schema contains
resetUid() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
resetUid() - Method in class org.apache.pig.newplan.logical.relational.LOSplitOutput
 
resetUid() - Method in class org.apache.pig.newplan.logical.relational.LOStream
 
resetUid() - Method in class org.apache.pig.newplan.logical.relational.LOUnion
 
resolve(URI) - Method in class org.apache.pig.parser.RegisterResolver
 
resolveClassName(String) - Static method in class org.apache.pig.impl.PigContext
 
resolveUnionSchema(Schema, Object) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
Called to resolve union.
ResourceFieldSchema() - Constructor for class org.apache.pig.ResourceSchema.ResourceFieldSchema
Construct an empty field schema.
ResourceFieldSchema(Schema.FieldSchema) - Constructor for class org.apache.pig.ResourceSchema.ResourceFieldSchema
Construct using a Schema.FieldSchema as the template.
ResourceFieldSchema(LogicalSchema.LogicalFieldSchema) - Constructor for class org.apache.pig.ResourceSchema.ResourceFieldSchema
Construct using a LogicalSchema.LogicalFieldSchema as the template.
ResourceFieldStatistics() - Constructor for class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
ResourceNotFoundException - Exception in org.apache.pig.impl.io
 
ResourceNotFoundException(String) - Constructor for exception org.apache.pig.impl.io.ResourceNotFoundException
 
resources - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.TezResourceManager
 
ResourceSchema - Class in org.apache.pig
A represenation of a schema used to communicate with load and store functions.
ResourceSchema() - Constructor for class org.apache.pig.ResourceSchema
Construct an empty ResourceSchema.
ResourceSchema(Schema) - Constructor for class org.apache.pig.ResourceSchema
Construct a ResourceSchema from a Schema
ResourceSchema(LogicalSchema) - Constructor for class org.apache.pig.ResourceSchema
Construct a ResourceSchema from a LogicalSchema
ResourceSchema(Schema, SortInfo) - Constructor for class org.apache.pig.ResourceSchema
Only for use by Pig internal code.
ResourceSchema(LogicalSchema, SortInfo) - Constructor for class org.apache.pig.ResourceSchema
Only for use by Pig internal code.
ResourceSchema.Order - Enum in org.apache.pig
 
ResourceSchema.ResourceFieldSchema - Class in org.apache.pig
 
resourceSchemaToAvroSchema(ResourceSchema, String, String, Map<String, List<Schema>>, Boolean) - Static method in class org.apache.pig.impl.util.avro.AvroStorageSchemaConversionUtilities
Translated a ResourceSchema to an Avro Schema.
ResourceStatistics - Class in org.apache.pig
An class that represents statistics about data to be loaded or stored.
ResourceStatistics() - Constructor for class org.apache.pig.ResourceStatistics
 
ResourceStatistics.ResourceFieldStatistics - Class in org.apache.pig
Statistics for a given field in the data.
restoreIn() - Static method in class org.apache.pig.tools.grunt.ConsoleReaderInputStream
Restore the original System.in input stream.
Result - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer
 
Result() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.Result
 
Result(byte, Object) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.Result
 
result - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.Result
 
result(String) - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
result(String) - Method in class org.apache.pig.tools.pigstats.PigStats
 
RESULT_EMPTY - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
RESULT_EOP - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
resultType - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
resultTypes - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
retainAll(Collection<?>) - Method in class org.apache.pig.impl.util.IdentityHashSet
 
retire() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.RunJarSecurityManager
 
retriable - Variable in exception org.apache.pig.PigException
 
retriable() - Method in exception org.apache.pig.PigException
Checks if the exception is retriable.
RETRIABLE_EXCEPTION - Static variable in class org.apache.pig.PigRunner.ReturnCode
 
retrieve(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.ObjectCache
Convenience method to retrieve objects cached for the vertex from ObjectRegistry
ReturnCode() - Constructor for class org.apache.pig.PigRunner.ReturnCode
 
returnCode - Variable in class org.apache.pig.tools.pigstats.PigStats
 
returnStatus - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.Result
 
returnType - Variable in class org.apache.pig.EvalFunc
Return type of this instance of EvalFunc.
returnUnlessNull(boolean, int) - Method in class org.apache.pig.data.SchemaTuple
 
returnUnlessNull(boolean, long) - Method in class org.apache.pig.data.SchemaTuple
 
returnUnlessNull(boolean, float) - Method in class org.apache.pig.data.SchemaTuple
 
returnUnlessNull(boolean, double) - Method in class org.apache.pig.data.SchemaTuple
 
returnUnlessNull(boolean, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
returnUnlessNull(boolean, DateTime) - Method in class org.apache.pig.data.SchemaTuple
 
returnUnlessNull(boolean, BigDecimal) - Method in class org.apache.pig.data.SchemaTuple
 
returnUnlessNull(boolean, BigInteger) - Method in class org.apache.pig.data.SchemaTuple
 
returnUnlessNull(boolean, Tuple) - Method in class org.apache.pig.data.SchemaTuple
 
returnUnlessNull(boolean, String) - Method in class org.apache.pig.data.SchemaTuple
 
returnUnlessNull(boolean, byte[]) - Method in class org.apache.pig.data.SchemaTuple
 
returnUnlessNull(boolean, DataBag) - Method in class org.apache.pig.data.SchemaTuple
 
returnUnlessNull(boolean, Map<String, Object>) - Method in class org.apache.pig.data.SchemaTuple
 
reverse(BaseOperatorPlan) - Method in class org.apache.pig.newplan.DotPlanDumper
 
reverse(BaseOperatorPlan) - Method in class org.apache.pig.newplan.logical.DotLOPrinter
 
reverse - Variable in class org.apache.pig.newplan.logical.optimizer.LogicalPlanPrinter
 
Reverse - Class in org.apache.pig.piggybank.evaluation.string
 
Reverse() - Constructor for class org.apache.pig.piggybank.evaluation.string.Reverse
 
ReverseDependencyOrderWalker<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.impl.plan
ReverseDependencyOrderWalker traverses the graph in such a way that no node is visited before all the nodes that are its successors on have been visited.
ReverseDependencyOrderWalker(P) - Constructor for class org.apache.pig.impl.plan.ReverseDependencyOrderWalker
 
ReverseDependencyOrderWalker - Class in org.apache.pig.newplan
Visit a plan in the reverse of the dependency order.
ReverseDependencyOrderWalker(OperatorPlan) - Constructor for class org.apache.pig.newplan.ReverseDependencyOrderWalker
 
ReverseDependencyOrderWalkerWOSeenChk - Class in org.apache.pig.newplan
Visit a plan in the reverse of the dependency order.
ReverseDependencyOrderWalkerWOSeenChk(OperatorPlan) - Constructor for class org.apache.pig.newplan.ReverseDependencyOrderWalkerWOSeenChk
 
revisit(PhysicalPlan) - Method in class org.apache.pig.pen.IllustratorAttacher
revisit an enhanced physical plan from MR compilation
rewind() - Method in class org.apache.pig.impl.util.RewindableIterator
 
RewindableIterator<E> - Class in org.apache.pig.impl.util
 
RewindableIterator(Iterator<E>) - Constructor for class org.apache.pig.impl.util.RewindableIterator
 
rewire(Operator<V>, int, Operator<V>, boolean) - Method in class org.apache.pig.impl.plan.Operator
Make any necessary changes to a node based on a change of position in the plan.
rhs - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
RINT - Class in org.apache.pig.piggybank.evaluation.math
math.RINT implements a binding to the Java function Math.rint(double).
RINT() - Constructor for class org.apache.pig.piggybank.evaluation.math.RINT
 
RollupDimensions - Class in org.apache.pig.builtin
Produces a DataBag with hierarchy of values (from the most detailed level of aggregation to most general level of aggregation) of the specified dimensions For example, (a, b, c) will produce the following bag:
RollupDimensions() - Constructor for class org.apache.pig.builtin.RollupDimensions
 
RollupDimensions(String) - Constructor for class org.apache.pig.builtin.RollupDimensions
 
ROUND - Class in org.apache.pig.builtin
ROUND implements a binding to the Java function Math.round(double).
ROUND() - Constructor for class org.apache.pig.builtin.ROUND
 
ROUND - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use ROUND
ROUND() - Constructor for class org.apache.pig.piggybank.evaluation.math.ROUND
Deprecated.
 
ROUND_TO - Class in org.apache.pig.builtin
ROUND_TO safely rounds a number to a given precision by using an intermediate BigDecimal.
ROUND_TO() - Constructor for class org.apache.pig.builtin.ROUND_TO
 
RoundRobinPartitioner - Class in org.apache.pig.builtin
Deprecated.
RoundRobinPartitioner() - Constructor for class org.apache.pig.builtin.RoundRobinPartitioner
Deprecated.
 
roundToEight(long) - Static method in class org.apache.pig.data.SizeUtil
Memory size of objects are rounded to multiple of 8 bytes
rowNum - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
rp - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
 
RTRIM - Class in org.apache.pig.builtin
Returns a string, with only tailing whitespace omitted.
RTRIM() - Constructor for class org.apache.pig.builtin.RTRIM
 
ruby - Static variable in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc
 
rubyArgToSchema(Object) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a helper function which converts objects into Schema objects.
RubyDataBag - Class in org.apache.pig.scripting.jruby
This provides a Ruby-esque way to interact with DataBag objects.
RubyDataBag(Ruby, RubyClass) - Constructor for class org.apache.pig.scripting.jruby.RubyDataBag
This constructor encapsulated an empty bag.
RubyDataBag(Ruby, RubyClass, DataBag) - Constructor for class org.apache.pig.scripting.jruby.RubyDataBag
This constructor encapsulates the bag that is passed to it.
RubyDataByteArray - Class in org.apache.pig.scripting.jruby
This class presents a native Ruby object for interacting with and manipulating DataByteArray objects.
RubyDataByteArray(Ruby, RubyClass) - Constructor for class org.apache.pig.scripting.jruby.RubyDataByteArray
This constructor encapsulated a null DataByteArray.
RubyDataByteArray(Ruby, RubyClass, DataByteArray) - Constructor for class org.apache.pig.scripting.jruby.RubyDataByteArray
Given a DataByteArray, this constructor creates a new one which copies the underlying bytes.
RubyDataByteArray(Ruby, RubyClass, DataByteArray, DataByteArray) - Constructor for class org.apache.pig.scripting.jruby.RubyDataByteArray
This constructor makes a RubyDataByteArray whose underlying bytes are a concatenation of the given bytes.
RubyDataByteArray(Ruby, RubyClass, byte[]) - Constructor for class org.apache.pig.scripting.jruby.RubyDataByteArray
This constructor creates a new DataByteArray with a reference to the provided bytes.
rubyEngine - Static variable in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc
 
rubyEngine - Static variable in class org.apache.pig.scripting.jruby.JrubyScriptEngine
 
RubySchema - Class in org.apache.pig.scripting.jruby
This class encapsulated a native Schema object, and provides a more convenient interface for manipulating Schemas.
RubySchema(Ruby, RubyClass) - Constructor for class org.apache.pig.scripting.jruby.RubySchema
 
RubySchema(Ruby, RubyClass, Schema, boolean) - Constructor for class org.apache.pig.scripting.jruby.RubySchema
This constructor sets the encapsulated Schema to be equal to the given Schema.
RubySchema(Ruby, RubyClass, Schema) - Constructor for class org.apache.pig.scripting.jruby.RubySchema
This constructor sets the encapsulated Schema to be equal to the given Schema.
RubySchema(Ruby, RubyClass, String) - Constructor for class org.apache.pig.scripting.jruby.RubySchema
This constructor is provided for convenience and sets the internal Schema equal to the result of a call to Utils.getSchemaFromString(java.lang.String).
rubyToPig(IRubyObject) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
This method facilitates conversion from Ruby objects to Pig objects.
rubyToPig(RubyArray) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
rubyToPig(RubyHash) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
rubyToPig(RubyBoolean) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
rubyToPig(RubySchema) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
rubyToPig(RubyString) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
rubyToPig(RubyBignum) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
rubyToPig(RubyFixnum) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
rubyToPig(RubyFloat) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
rubyToPig(RubyInteger) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
rubyToPig(RubyDataBag) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
rubyToPig(RubyDataByteArray) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
rubyToPig(RubyNil) - Static method in class org.apache.pig.scripting.jruby.PigJrubyLibrary
A type specific conversion routine.
Rule - Class in org.apache.pig.newplan.optimizer
Rules describe a pattern of operators.
Rule(String, boolean) - Constructor for class org.apache.pig.newplan.optimizer.Rule
Create this rule by using the default pattern that this rule provided
Rule(String, OperatorPlan) - Constructor for class org.apache.pig.newplan.optimizer.Rule
 
ruleSets - Variable in class org.apache.pig.newplan.optimizer.PlanOptimizer
 
run() - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher.HangingJobKiller
 
run(Map<String, LogicalInput>, Map<String, LogicalOutput>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
run() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
run() - Method in class org.apache.pig.backend.hadoop.PigJobControl
The main loop for the thread.
run() - Method in class org.apache.pig.impl.builtin.StreamingUDF.ProcessKiller
 
run() - Method in class org.apache.pig.impl.streaming.ExecutableManager
Start execution of the ExecutableManager.
run(String[], PigProgressNotificationListener) - Static method in class org.apache.pig.PigRunner
 
run() - Method in class org.apache.pig.scripting.BoundScript
Run multiple instances of bound pipeline on Hadoop in parallel.
run(Properties) - Method in class org.apache.pig.scripting.BoundScript
Run multiple instances of bound pipeline on Hadoop in parallel.
run(String) - Method in class org.apache.pig.scripting.BoundScript
Run multiple instances of bound pipeline on Hadoop in parallel.
run(PigContext, String) - Method in class org.apache.pig.scripting.ScriptEngine
Runs a script file.
run() - Method in class org.apache.pig.tools.grunt.Grunt
 
run() - Method in class org.apache.pig.tools.grunt.GruntParser.StreamPrinter
 
RunJarSecurityManager - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
RunJarSecurityManager() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.RunJarSecurityManager
 
runJob() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.NativeMapReduceOper
 
runJob() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.NativeSparkOperator
 
runJob(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.NativeTezOper
 
runPipeline(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
 
runPipeline(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.MapWithPartitionIndex
 
runPipeline(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
 
runPipeline(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
runPlan(LogicalPlan, String) - Method in class org.apache.pig.tools.ToolsPigServer
Given a (modified) new logical plan, run the script.
runSingle() - Method in class org.apache.pig.scripting.BoundScript
Run a pipeline on Hadoop.
runSingle(Properties) - Method in class org.apache.pig.scripting.BoundScript
Run a pipeline on Hadoop.
runSingle(String) - Method in class org.apache.pig.scripting.BoundScript
Run a pipeline on Hadoop.
runSQLCommand(String, String, boolean) - Static method in class org.apache.pig.tools.grunt.GruntParser
 

S

safeIncrCounter(String, String, Long) - Static method in class org.apache.pig.TypedOutputEvalFunc
 
SAMPLE_VERTEX - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
sampleContents() - Method in class org.apache.pig.data.DefaultAbstractBag
Sample every SPILL_SAMPLE_FREQUENCYth tuple until we reach a max of SPILL_SAMPLE_SIZE to get an estimate of the tuple sizes.
SampleLoader - Class in org.apache.pig.impl.builtin
Abstract class that specifies the interface for sample loaders
SampleLoader(String) - Constructor for class org.apache.pig.impl.builtin.SampleLoader
 
sampleMap - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
SampleOptimizer - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
A visitor to optimize plans that have a sample job that immediately follows a load/store only MR job.
SampleOptimizer(MROperPlan, PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SampleOptimizer
 
sampleRate - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
samples - Variable in class org.apache.pig.impl.builtin.FindQuantiles
 
sampleVertex - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
ScalarExpression - Class in org.apache.pig.newplan.logical.expression
 
ScalarExpression(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.expression.ScalarExpression
 
ScalarExpression(OperatorPlan, Operator, Operator) - Constructor for class org.apache.pig.newplan.logical.expression.ScalarExpression
 
ScalarPhyFinder - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
 
ScalarPhyFinder(PhysicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.ScalarPhyFinder
 
scalars - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
scalars - Variable in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
scalars - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
ScalarVariableValidator - Class in org.apache.pig.newplan.logical.visitor
This validator checks the correctness of use of scalar variables in logical operators.
ScalarVariableValidator(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.ScalarVariableValidator
 
ScalarVariableValidator.ProjectFinder - Class in org.apache.pig.newplan.logical.visitor
 
ScalarVisitor - Class in org.apache.pig.newplan.logical.visitor
Logical plan visitor which handles scalar projections.
ScalarVisitor(OperatorPlan, PigContext, String) - Constructor for class org.apache.pig.newplan.logical.visitor.ScalarVisitor
 
SCALB - Class in org.apache.pig.piggybank.evaluation.math
math.SCALB implements a binding to the Java function Math.scalb(double,int).
SCALB() - Constructor for class org.apache.pig.piggybank.evaluation.math.SCALB
 
ScanIndex(Tuple) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Scans the index looking for a given key.
schedulingType - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
schema - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
schema - Variable in class org.apache.pig.builtin.AvroStorage
 
schema - Variable in class org.apache.pig.builtin.JsonLoader
 
schema - Variable in class org.apache.pig.builtin.JsonStorage
 
schema(String) - Static method in class org.apache.pig.builtin.mock.Storage
 
schema - Variable in class org.apache.pig.builtin.PigStorage
 
Schema - Class in org.apache.pig.impl.logicalLayer.schema
The Schema class encapsulates the notion of a schema for a relational operator.
Schema() - Constructor for class org.apache.pig.impl.logicalLayer.schema.Schema
 
Schema(List<Schema.FieldSchema>) - Constructor for class org.apache.pig.impl.logicalLayer.schema.Schema
 
Schema(Schema.FieldSchema) - Constructor for class org.apache.pig.impl.logicalLayer.schema.Schema
Create a schema with only one field.
Schema(Schema) - Constructor for class org.apache.pig.impl.logicalLayer.schema.Schema
Copy Constructor.
schema - Variable in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
If this is a tuple itself, it can have a schema.
schema - Variable in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
schema - Variable in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
schema - Variable in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
schema - Variable in class org.apache.pig.piggybank.storage.DBStorage
 
Schema.FieldSchema - Class in org.apache.pig.impl.logicalLayer.schema
 
SCHEMA_TUPLE - Static variable in class org.apache.pig.data.BinInterSedes
 
SCHEMA_TUPLE_BYTE_INDEX - Static variable in class org.apache.pig.data.BinInterSedes
 
SCHEMA_TUPLE_ON_BY_DEFAULT - Static variable in class org.apache.pig.PigConstants
 
SCHEMA_TUPLE_SHORT_INDEX - Static variable in class org.apache.pig.data.BinInterSedes
 
SCHEMA_TUPLE_SHOULD_ALLOW_FORCE - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
SCHEMA_TUPLE_SHOULD_USE_IN_FOREACH - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
SCHEMA_TUPLE_SHOULD_USE_IN_FRJOIN - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
SCHEMA_TUPLE_SHOULD_USE_IN_MERGEJOIN - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
SCHEMA_TUPLE_SHOULD_USE_IN_UDF - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
SchemaAliasVisitor - Class in org.apache.pig.newplan.logical.visitor
 
SchemaAliasVisitor(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
schemaEqualsForMatching(Schema, Schema, EvalFunc.SchemaType, boolean) - Static method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
Compare two schemas for equality for argument matching purposes.
SchemaKey(Schema) - Constructor for class org.apache.pig.data.utils.StructuresHelper.SchemaKey
 
SchemaMergeException - Exception in org.apache.pig.impl.logicalLayer.schema
 
SchemaMergeException() - Constructor for exception org.apache.pig.impl.logicalLayer.schema.SchemaMergeException
Create a new FrontendException with null as the error message.
SchemaMergeException(String) - Constructor for exception org.apache.pig.impl.logicalLayer.schema.SchemaMergeException
Create a new FrontendException with the specified message and cause.
SchemaMergeException(Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.schema.SchemaMergeException
Create a new FrontendException with the specified cause.
SchemaMergeException(String, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.schema.SchemaMergeException
Create a new FrontendException with the specified message and cause.
SchemaMergeException(String, int) - Constructor for exception org.apache.pig.impl.logicalLayer.schema.SchemaMergeException
Create a new FrontendException with the specified message and cause.
SchemaMergeException(String, int, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.schema.SchemaMergeException
Create a new FrontendException with the specified message and cause.
SchemaMergeException(String, int, byte) - Constructor for exception org.apache.pig.impl.logicalLayer.schema.SchemaMergeException
Create a new FrontendException with the specified message and cause.
SchemaMergeException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.schema.SchemaMergeException
Create a new FrontendException with the specified message and cause.
SchemaMergeException(String, int, boolean) - Constructor for exception org.apache.pig.impl.logicalLayer.schema.SchemaMergeException
Create a new FrontendException with the specified message and cause.
SchemaMergeException(String, int, byte, boolean) - Constructor for exception org.apache.pig.impl.logicalLayer.schema.SchemaMergeException
Create a new FrontendException with the specified message and cause.
SchemaMergeException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.impl.logicalLayer.schema.SchemaMergeException
Create a new FrontendException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
SchemaMergeException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.schema.SchemaMergeException
Create a new FrontendException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
schemaName - Variable in class org.apache.pig.builtin.COR.Final
 
schemaName - Variable in class org.apache.pig.builtin.COR
 
schemaName - Variable in class org.apache.pig.builtin.COV.Final
 
schemaName - Variable in class org.apache.pig.builtin.COV
 
schemaName - Variable in class org.apache.pig.piggybank.evaluation.stats.COR.Final
Deprecated.
 
schemaName - Variable in class org.apache.pig.piggybank.evaluation.stats.COR
Deprecated.
 
schemaName - Variable in class org.apache.pig.piggybank.evaluation.stats.COV.Final
Deprecated.
 
schemaName - Variable in class org.apache.pig.piggybank.evaluation.stats.COV
Deprecated.
 
SchemaNotDefinedException - Exception in org.apache.pig.newplan.logical.relational
 
SchemaNotDefinedException(Throwable) - Constructor for exception org.apache.pig.newplan.logical.relational.SchemaNotDefinedException
 
SchemaNotDefinedException(String, Throwable) - Constructor for exception org.apache.pig.newplan.logical.relational.SchemaNotDefinedException
 
SchemaNotDefinedException(String) - Constructor for exception org.apache.pig.newplan.logical.relational.SchemaNotDefinedException
 
SchemaPatcher - Class in org.apache.pig.newplan.logical.optimizer
A PlanTransformListener for the logical optimizer that will patch up schemas after a plan has been transformed.
SchemaPatcher() - Constructor for class org.apache.pig.newplan.logical.optimizer.SchemaPatcher
 
SchemaResetter - Class in org.apache.pig.newplan.logical.optimizer
 
SchemaResetter(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
SchemaResetter(OperatorPlan, boolean) - Constructor for class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
schemaSize() - Method in class org.apache.pig.data.SchemaTuple
 
schemaToType(Object, ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
schemaToType(Object, int, ResourceSchema.ResourceFieldSchema[]) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
SchemaTuple<T extends SchemaTuple<T>> - Class in org.apache.pig.data
A SchemaTuple is a type aware tuple that is much faster and more memory efficient.
SchemaTuple() - Constructor for class org.apache.pig.data.SchemaTuple
 
SchemaTuple.SchemaTupleQuickGenerator<A> - Class in org.apache.pig.data
 
SchemaTupleBackend - Class in org.apache.pig.data
 
SchemaTupleClassGenerator - Class in org.apache.pig.data
This class encapsulates the generation of SchemaTuples, as well as some logic around shipping code to the distributed cache.
SchemaTupleClassGenerator.GenContext - Enum in org.apache.pig.data
The GenContext mechanism provides a level of control in where SchemaTupleFactories are used.
SchemaTupleClassGenerator.GenContext.GenerateForceLoad - Annotation Type in org.apache.pig.data
 
SchemaTupleClassGenerator.GenContext.GenerateForeach - Annotation Type in org.apache.pig.data
 
SchemaTupleClassGenerator.GenContext.GenerateFrJoin - Annotation Type in org.apache.pig.data
 
SchemaTupleClassGenerator.GenContext.GenerateMergeJoin - Annotation Type in org.apache.pig.data
 
SchemaTupleClassGenerator.GenContext.GenerateUdf - Annotation Type in org.apache.pig.data
These annotations are used to mark a given SchemaTuple with the context in which is was intended to be generated.
SchemaTupleFactory - Class in org.apache.pig.data
This is an implementation of TupleFactory that will instantiate SchemaTuple's.
SchemaTupleFactory(Class<SchemaTuple<?>>, SchemaTuple.SchemaTupleQuickGenerator<? extends SchemaTuple<?>>) - Constructor for class org.apache.pig.data.SchemaTupleFactory
 
SchemaTupleFrontend - Class in org.apache.pig.data
This class is to be used at job creation time.
SchemaTupleFrontend() - Constructor for class org.apache.pig.data.SchemaTupleFrontend
 
SchemaTupleQuickGenerator() - Constructor for class org.apache.pig.data.SchemaTuple.SchemaTupleQuickGenerator
 
SchemaUtil - Class in org.apache.pig.impl.logicalLayer.schema
A utility class for simplify the schema creation, especially for bag and tuple schema.
SchemaUtil() - Constructor for class org.apache.pig.impl.logicalLayer.schema.SchemaUtil
 
scope - Variable in class org.apache.pig.impl.plan.OperatorKey
 
scope - Variable in class org.apache.pig.PigServer
 
ScriptEngine - Class in org.apache.pig.scripting
Base class for various scripting implementations
ScriptEngine() - Constructor for class org.apache.pig.scripting.ScriptEngine
 
ScriptEngine.SupportedScriptLang - Enum in org.apache.pig.scripting
 
scriptFeatures - Variable in class org.apache.pig.tools.pigstats.ScriptState
 
scriptFiles - Variable in class org.apache.pig.impl.PigContext
Deprecated.
ScriptingOutputCapturer - Class in org.apache.pig.scripting
This class helps a scripting UDF capture user output by managing when to capture output and where the output is written to.
ScriptingOutputCapturer(ExecType) - Constructor for class org.apache.pig.scripting.ScriptingOutputCapturer
 
scriptingUDFs - Variable in class org.apache.pig.impl.PigContext
 
scriptJars - Variable in class org.apache.pig.impl.PigContext
 
ScriptPigContext - Class in org.apache.pig.scripting
Context for embedded Pig script.
ScriptState - Class in org.apache.pig.tools.pigstats
ScriptStates encapsulates settings for a Pig script that runs on a hadoop cluster.
ScriptState(String) - Constructor for class org.apache.pig.tools.pigstats.ScriptState
 
ScriptState.AliasVisitor - Class in org.apache.pig.tools.pigstats
 
ScriptState.FeatureVisitor - Class in org.apache.pig.tools.pigstats
 
ScriptState.PIG_FEATURE - Enum in org.apache.pig.tools.pigstats
Features used in a Pig script
ScriptState.PIG_PROPERTY - Enum in org.apache.pig.tools.pigstats
Keys of Pig settings added to Jobs
SearchEngineExtractor - Class in org.apache.pig.piggybank.evaluation.util.apachelogparser
SearchEngineExtractor takes a url string and extracts the search engine.
SearchEngineExtractor() - Constructor for class org.apache.pig.piggybank.evaluation.util.apachelogparser.SearchEngineExtractor
 
SearchQuery - Class in org.apache.pig.piggybank.evaluation.util
This small UDF takes a search engine URL (Google/Yahoo/AOL/Live) containing the search query and extracts it.
SearchQuery() - Constructor for class org.apache.pig.piggybank.evaluation.util.SearchQuery
 
SearchTermExtractor - Class in org.apache.pig.piggybank.evaluation.util.apachelogparser
SearchTermExtractor takes a url string and extracts the search terms.
SearchTermExtractor() - Constructor for class org.apache.pig.piggybank.evaluation.util.apachelogparser.SearchTermExtractor
 
second - Variable in class org.apache.pig.impl.util.Pair
 
SecondaryKeyOptimizer - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
SecondaryKeyOptimizer(MROperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SecondaryKeyOptimizer
 
SecondaryKeyOptimizer - Interface in org.apache.pig.backend.hadoop.executionengine.optimizer
 
SecondaryKeyOptimizerInfo() - Constructor for class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil.SecondaryKeyOptimizerInfo
 
SecondaryKeyOptimizerMR - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
SecondaryKeyOptimizerMR(MROperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SecondaryKeyOptimizerMR
 
SecondaryKeyOptimizerSpark - Class in org.apache.pig.backend.hadoop.executionengine.spark.optimizer
Secondary key sort optimization for spark mode
SecondaryKeyOptimizerSpark(SparkOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.SecondaryKeyOptimizerSpark
 
SecondaryKeyOptimizerTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
 
SecondaryKeyOptimizerTez(TezOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.SecondaryKeyOptimizerTez
 
SecondaryKeyOptimizerUtil - Class in org.apache.pig.backend.hadoop.executionengine.util
 
SecondaryKeyOptimizerUtil() - Constructor for class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil
 
SecondaryKeyOptimizerUtil.SecondaryKeyOptimizerInfo - Class in org.apache.pig.backend.hadoop.executionengine.util
 
SecondaryKeyPartitioner - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners
 
SecondaryKeyPartitioner() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SecondaryKeyPartitioner
 
SecondaryKeySortUtil - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
Provide utility functions which is used by ReducedByConverter and JoinGroupSparkConverter.
SecondaryKeySortUtil() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.SecondaryKeySortUtil
 
secondaryKeyType - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
secondaryLeafOps - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
secondaryPlans - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
SecondsBetween - Class in org.apache.pig.builtin
SecondsBetween returns the number of seconds between two DateTime objects
SecondsBetween() - Constructor for class org.apache.pig.builtin.SecondsBetween
 
SecurityHelper - Class in org.apache.pig.backend.hadoop.executionengine.tez.util
This class duplicates some security related private methods from org.apache.hadoop.mapreduce.JobSubmitter for Tez.
SedesHelper - Class in org.apache.pig.data.utils
 
SedesHelper() - Constructor for class org.apache.pig.data.utils.SedesHelper
 
SedesHelper.Varint - Class in org.apache.pig.data.utils
Encodes signed and unsigned values using a common variable-length scheme, found for example in Google's Protocol Buffers.
seek(long, SeekableInputStream.FLAGS) - Method in class org.apache.pig.backend.datastorage.SeekableInputStream
Seeks to a given offset as specified by whence flags.
seek(long, SeekableInputStream.FLAGS) - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
seek(long) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorageInputStream
 
seek(long) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader.IndexedStorageLineReader
If given offset is within the buffer, adjust the buffer position to read from otherwise seek to the given offset from start of the file.
seek(long) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader
 
SeekableInputStream - Class in org.apache.pig.backend.datastorage
Unix-like API for an input stream that supports random access.
SeekableInputStream() - Constructor for class org.apache.pig.backend.datastorage.SeekableInputStream
 
SeekableInputStream.FLAGS - Enum in org.apache.pig.backend.datastorage
 
seekNear(Tuple) - Method in class org.apache.pig.impl.builtin.DefaultIndexableLoader
 
seekNear(Tuple) - Method in interface org.apache.pig.IndexableLoadFunc
This method is called by the Pig runtime to indicate to the LoadFunc to position its underlying input stream near the keys supplied as the argument.
seekNear(Tuple) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader
Scan the index for given key and seek to appropriate offset in the data
seekNear(Tuple) - Method in class org.apache.pig.piggybank.storage.IndexedStorage
 
SeekToIndexFooter() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Seeks to the index footer
selectExecType(Properties) - Static method in class org.apache.pig.ExecTypeProvider
 
SelfSpillBag - Class in org.apache.pig.data
Class to hold code common to self spilling bags such as InternalCachedBag
SelfSpillBag(int) - Constructor for class org.apache.pig.data.SelfSpillBag
 
SelfSpillBag(int, float) - Constructor for class org.apache.pig.data.SelfSpillBag
 
SelfSpillBag.MemoryLimits - Class in org.apache.pig.data
This class helps to compute the number of entries that should be held in memory so that memory consumption is limited.
SEPERATE - Static variable in class org.apache.pig.newplan.logical.optimizer.LogicalPlanPrinter
 
SequenceFileInterStorage - Class in org.apache.pig.impl.io
Store tuples (BinSedesTuples, specifically) using sequence files to leverage sequence file's compression features.
SequenceFileInterStorage() - Constructor for class org.apache.pig.impl.io.SequenceFileInterStorage
Simple binary nested reader format
SequenceFileInterStorage.SequenceFileTupleOutputFormat - Class in org.apache.pig.impl.io
 
SequenceFileLoader - Class in org.apache.pig.piggybank.storage
A Loader for Hadoop-Standard SequenceFiles.
SequenceFileLoader() - Constructor for class org.apache.pig.piggybank.storage.SequenceFileLoader
 
SequenceFileTupleOutputFormat() - Constructor for class org.apache.pig.impl.io.SequenceFileInterStorage.SequenceFileTupleOutputFormat
 
serializationFactory - Variable in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
serialize(Serializable) - Static method in class org.apache.pig.impl.util.ObjectSerializer
 
serialize(Configuration) - Method in class org.apache.pig.impl.util.UDFContext
Serialize the UDF specific information into an instance of JobConf.
serialize() - Method in class org.apache.pig.impl.util.UDFContext
 
serialize(Tuple) - Method in class org.apache.pig.PigStreamingBase
Deprecated.
serialize(Tuple) - Method in interface org.apache.pig.PigToStream
Deprecated.
Given a tuple, produce an array of bytes to be passed to the streaming executable.
serializedScript - Variable in class org.apache.pig.tools.pigstats.ScriptState
 
serializeJobConf(JobConf) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.KryoSerializer
 
serializer - Variable in class org.apache.pig.impl.streaming.InputHandler
 
serializeToBytes(Tuple) - Method in class org.apache.pig.builtin.PigStreaming
 
serializeToBytes(Tuple) - Method in class org.apache.pig.impl.streaming.PigStreamingUDF
 
serializeToBytes(Tuple) - Method in class org.apache.pig.PigStreamingBase
Given a tuple, produce an array of bytes to be passed to the streaming executable.
serializeUDFContext(Configuration, TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezUDFContextSeparator
 
serializeUDFContext(Configuration, TezOperator, UDFContextSeparator.UDFType) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezUDFContextSeparator
 
serializeUDFContext(Configuration, TezOperator, POStore) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezUDFContextSeparator
 
serializeUDFContext(Configuration, String, UDFContextSeparator.UDFType...) - Method in class org.apache.pig.impl.util.UDFContextSeparator
 
serializeUDFContext(Configuration, String, POStore) - Method in class org.apache.pig.impl.util.UDFContextSeparator
 
serializeUDFContextForEdge(Configuration, TezOperator, TezOperator, UDFContextSeparator.UDFType) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezUDFContextSeparator
 
serialVersionUID - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
serialVersionUID - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
serialVersionUID - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
serialVersionUID - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
serialVersionUID - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
set(BigDecimal) - Method in class org.apache.pig.backend.hadoop.BigDecimalWritable
 
set(BigInteger) - Method in class org.apache.pig.backend.hadoop.BigIntegerWritable
 
set(DateTime) - Method in class org.apache.pig.backend.hadoop.DateTimeWritable
 
set(double) - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
set(String, String, Collection<Tuple>) - Method in class org.apache.pig.builtin.mock.Storage.Data
to set the data in a location with a known schema
set(String, String, Tuple...) - Method in class org.apache.pig.builtin.mock.Storage.Data
to set the data in a location with a known schema
set(String, Schema, Collection<Tuple>) - Method in class org.apache.pig.builtin.mock.Storage.Data
to set the data in a location with a known schema
set(String, Schema, Tuple...) - Method in class org.apache.pig.builtin.mock.Storage.Data
to set the data in a location with a known schema
set(String, Collection<Tuple>) - Method in class org.apache.pig.builtin.mock.Storage.Data
to set the data in a location
set(String, Tuple...) - Method in class org.apache.pig.builtin.mock.Storage.Data
to set the data in a location
set(SchemaTuple<?>, boolean) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
set(List<Object>) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
set(int, Object) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
set(byte[]) - Method in class org.apache.pig.data.DataByteArray
Set the internal byte array.
set(String) - Method in class org.apache.pig.data.DataByteArray
Set the internal byte array.
set(int, Object) - Method in class org.apache.pig.data.DefaultTuple
Set the value in a given field.
set(SchemaTuple<?>, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
set(Tuple) - Method in class org.apache.pig.data.SchemaTuple
 
set(Tuple, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
set(SchemaTuple<?>) - Method in class org.apache.pig.data.SchemaTuple
 
set(List<Object>) - Method in class org.apache.pig.data.SchemaTuple
 
set(int, Object) - Method in class org.apache.pig.data.SchemaTuple
 
set(int, Object) - Method in class org.apache.pig.data.TargetedTuple
 
set(int, Object) - Method in interface org.apache.pig.data.Tuple
Set the value in a given field.
set(int, Object) - Method in class org.apache.pig.data.UnlimitedNullTuple
 
set(int, Object) - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
set(int, Object) - Method in class org.apache.pig.pen.util.ExampleTuple
 
set(IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubyDataByteArray
This method calls the set method of the underlying DataByteArray with one exception: if given a RubyDataByteArray, it will set the encapsulated DataByteArray to be equal.
set(ThreadContext, IRubyObject[]) - Method in class org.apache.pig.scripting.jruby.RubySchema
This allows the users to set an index or a range of values to a specified RubySchema.
set(String, String) - Static method in class org.apache.pig.scripting.js.JSPig
See Pig
set(String, String) - Static method in class org.apache.pig.scripting.Pig
Set a variable for use in Pig Latin.
set(PigContext, ScriptEngine) - Static method in class org.apache.pig.scripting.ScriptPigContext
 
setAccumEnd() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setAccumEnd() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
setAccumStart() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
setAccumStart() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setAccumStart() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
setAccumulative() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setAccumulative() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
setActiveContainer(ContainerDescriptor) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
setActiveContainer(ContainerDescriptor) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
setAddedFields(List<Integer>) - Method in class org.apache.pig.impl.plan.ProjectionMap
 
setAggregate(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigHadoopLogger
 
setAlgebraicFunction(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
setAlias(String) - Method in class org.apache.pig.LoadPushDown.RequiredField
 
setAlias(String) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
setAlias(SparkOperator) - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
setAmendKey(Object) - Method in class org.apache.pig.data.AmendableTuple
 
setAndCatch(Tuple) - Method in class org.apache.pig.data.SchemaTuple
 
setAndCatch(SchemaTuple<?>) - Method in class org.apache.pig.data.SchemaTuple
 
setAppendedFields(Tuple) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
setAscendingCol(List<Boolean>) - Method in class org.apache.pig.newplan.logical.relational.LORank
 
setAscendingCols(List<Boolean>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
setAscendingCols(List<Boolean>) - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
setAscendingColumns(List<Boolean>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
setAttachedLogicalOperator(Operator) - Method in class org.apache.pig.newplan.logical.expression.ScalarExpression
 
setAttachedRelationalOp(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
setAvgRecordSize(Long) - Method in class org.apache.pig.ResourceStatistics
Set average record size in bytes
setBackendException(String, Exception) - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
setBackendException(Exception) - Method in class org.apache.pig.tools.pigstats.JobStats
 
setBackendException(Job, Exception) - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
 
setBackendException(String, Exception) - Method in class org.apache.pig.tools.pigstats.PigStats
 
setBagColumns(List<Integer>) - Method in class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
setBatchOn() - Method in class org.apache.pig.PigServer
Starts batch execution mode.
setBigDecimal(int, BigDecimal) - Method in class org.apache.pig.data.SchemaTuple
 
setBigDecimal(int, BigDecimal) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setBigInteger(int, BigInteger) - Method in class org.apache.pig.data.SchemaTuple
 
setBigInteger(int, BigInteger) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setBitByPos(byte, boolean, int) - Static method in class org.apache.pig.data.utils.BytesHelper
 
setBloomKeyType(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.BloomPackager
 
setBloomOutputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
setBoolean(int, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
setBoolean(int, boolean) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setBranchFlag() - Method in class org.apache.pig.pen.util.PreOrderDepthFirstWalker
 
setBroadcastedVariableName(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POBroadcastSpark
Set your broadcast variable name so that BroadcastConverter can put this broadcasted variable in a map which can be referenced by other functions / closures in Converters
setBytes(int, byte[]) - Method in class org.apache.pig.data.SchemaTuple
 
setBytes(int, byte[]) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setBytes(long) - Method in class org.apache.pig.tools.pigstats.OutputStats
 
setCacheFiles(List<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
setCacheFiles(List<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
setCacheFiles(List<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setCastState(LOLoad.CastState) - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
setCastState(LOStream.CastState) - Method in class org.apache.pig.newplan.logical.relational.LOStream
 
setChanges(boolean) - Method in class org.apache.pig.impl.plan.ProjectionMap
 
setChunkSize(long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.JoinPackager
 
setClassLoader(ClassLoader) - Static method in class org.apache.pig.impl.PigContext
 
setClassName(Class<?>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternNode
 
setClassName(String) - Method in class org.apache.pig.FuncSpec
 
setClientSystemProps(Properties) - Method in class org.apache.pig.impl.util.UDFContext
 
setClosed(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setColNum(int) - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
Set the column number for this project.
setColumn(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
setColumnInfoList(List<HBaseStorage.ColumnInfo>) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
Updates the ColumnInfo List.
setColumnNumber(Configuration, int) - Static method in class org.apache.pig.piggybank.storage.hiverc.HiveRCOutputFormat
set number of columns into the given configuration.
setColumnNumberFromAlias() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
If there is an alias, finds the column number from it.
setColumns(ArrayList<Integer>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
setCombiner(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.BloomPackager
 
setCombinerInMap(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
setCombinerInReducer(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
setCommandArgs(String[]) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Set the command line arguments for the StreamingCommand.
setCommandLine(String) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
setCond(ExpressionOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SecondaryKeyPartitioner
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SkewedPartitioner
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBigDecimalRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBigIntegerRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBooleanRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBytesRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigDateTimeRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigDoubleRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigFloatRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigIntRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigLongRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSecondaryKeyComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
(non-Javadoc)
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTextRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleDefaultRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleSortComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
setConf(Configuration) - Method in class org.apache.pig.builtin.RoundRobinPartitioner
Deprecated.
 
setConf(Configuration) - Method in class org.apache.pig.data.BinInterSedes.BinInterSedesTupleRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.data.DefaultTuple.DefaultTupleRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.tools.pigstats.InputStats
 
setConf(Configuration) - Method in class org.apache.pig.tools.pigstats.JobStats
 
setConf(Configuration) - Method in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
setConf(Configuration) - Method in class org.apache.pig.tools.pigstats.OutputStats
 
setConf(Configuration) - Method in class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
setConf(Configuration) - Method in class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
setConfiguration(Properties) - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Responsible for updating the properties for the ExecutionEngine.
setConfiguration(Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
setConnectedToPackage(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
setConsoleReader(ConsoleReader) - Method in class org.apache.pig.tools.grunt.Grunt
 
setConstExpr(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORegexp
 
setConstExpr(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.regex.RegexInit
 
setContext(TaskContext<?>) - Method in class org.apache.pig.tools.pigstats.PigStatusReporter
 
setCounterPlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
setCounters(SparkCounters) - Method in class org.apache.pig.tools.pigstats.spark.SparkPigStatusReporter
 
setCross(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
setCross(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
setCtorArgs(String[]) - Method in class org.apache.pig.FuncSpec
 
setCurrentIdx(int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
setCurrentIdx(int) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
setCurrentIdx(int) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
setCurrentIdx(int) - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit
 
setCustomPartitioner(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
setCustomPartitioner(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
setCustomPartitioner(String) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
setCustomPartitioner(String, TezOperator) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
setCustomPartitioner(String) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
setDAGScriptInfo(TezPlanContainerNode) - Method in class org.apache.pig.tools.pigstats.tez.TezScriptState
 
setDataBag(int, DataBag) - Method in class org.apache.pig.data.SchemaTuple
 
setDataBag(int, DataBag) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setDateTime(int, DateTime) - Method in class org.apache.pig.data.SchemaTuple
 
setDateTime(int, DateTime) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setDefaultLogLevel(Level) - Method in class org.apache.pig.impl.PigContext
 
setDefaultParallel(int) - Method in class org.apache.pig.PigServer
Set the default parallelism for this job
setDefaultParallelism(int) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigContext
 
setDefaultTimeZone(Configuration) - Static method in class org.apache.pig.impl.util.Utils
 
setDeflateLevel(Job, int) - Static method in class org.apache.pig.piggybank.storage.avro.PigAvroOutputFormat
Enable output compression using the deflate codec and specify its level.
setDescription(String) - Method in class org.apache.pig.ResourceSchema.ResourceFieldSchema
Set the description
setDetailedMessage(String) - Method in exception org.apache.pig.PigException
Set the detailed message of the exception
setDisableCounter(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
setDisableCounter(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setDisableCounter(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
setDisableCounter(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
setDisableCounter(boolean) - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit
 
setDisplayName(String) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounter
 
setDistinct(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.LitePackager
 
setDistinct(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
setDistinct(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
setDontEstimateParallelism(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setDouble(int, double) - Method in class org.apache.pig.data.SchemaTuple
 
setDouble(int, double) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setEndAlias(String) - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
setEndCol(int) - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
setEndOfAllInput(boolean) - Method in class org.apache.pig.builtin.HiveUDTF
 
setEndOfAllInput(boolean) - Method in class org.apache.pig.EvalFunc
 
setEndOfAllInputInMap(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setEndOfAllInputInReduce(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setEndOfInput(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
setEndOfInput(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
setEndOfInput(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
setEndOfInput(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POPoissonSampleSpark
 
setEndOfRecordMark(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
setEqClassesShared() - Method in class org.apache.pig.pen.Illustrator
 
setEquivalenceClasses(LinkedList<IdentityHashSet<Tuple>>, PhysicalOperator) - Method in class org.apache.pig.pen.Illustrator
 
setErrorCode(int) - Method in exception org.apache.pig.PigException
Set the error code of the exception
setErrorCode(int) - Method in class org.apache.pig.tools.pigstats.PigStats
 
setErrorCode(int) - Static method in class org.apache.pig.tools.pigstats.PigStatsUtil
 
setErrorMessage(String) - Method in class org.apache.pig.tools.pigstats.PigStats
 
setErrorMessage(String) - Static method in class org.apache.pig.tools.pigstats.PigStatsUtil
 
setErrorMsg(String) - Method in class org.apache.pig.tools.pigstats.JobStats
 
setErrorSource(byte) - Method in exception org.apache.pig.PigException
Set the error source of the exception
setErrorThrowable(Throwable) - Method in class org.apache.pig.tools.pigstats.PigStats
 
setErrorThrowable(Throwable) - Static method in class org.apache.pig.tools.pigstats.PigStatsUtil
 
setEstimatedParallelism(int) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setEstimatedParallelism(int) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperPlan
 
setException(Exception) - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
setExecType(ExecType) - Method in class org.apache.pig.impl.PigContext
 
setExecutable(String) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Set the executable for the StreamingCommand.
setExplainState(GruntParser.ExplainState) - Method in class org.apache.pig.tools.grunt.GruntParser
 
setExpr(ExpressionOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryExpressionOperator
Set the contained expression explicitly.
setExpressionPlans(MultiMap<Integer, LogicalExpressionPlan>) - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
 
setExpressionPlans(MultiMap<Integer, LogicalExpressionPlan>) - Method in class org.apache.pig.newplan.logical.relational.LOCube
 
setFetchable(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
setFieldDel(byte) - Method in class org.apache.pig.builtin.JsonMetadata
 
setFields(List<Pair<Integer, Integer>>) - Method in class org.apache.pig.impl.plan.RequiredFields
 
setFields(ResourceSchema.ResourceFieldSchema[]) - Method in class org.apache.pig.ResourceSchema
Set all the fields.
setFields(ResourceStatistics.ResourceFieldStatistics[]) - Method in class org.apache.pig.ResourceStatistics
 
setFieldSchema(ResourceSchema.ResourceFieldSchema) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
setFieldSchemaDefaultType(Schema.FieldSchema, byte) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Recursively set NULL type to the specifid type
setFileName(String) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
setFilter(DataByteArray) - Method in class org.apache.pig.builtin.Bloom
For testing only, do not use directly.
setFilterPlan(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.relational.LOFilter
 
setFilterPlan(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.relational.LOSplitOutput
 
setFlattenFlags(boolean[]) - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
setFloat(int, float) - Method in class org.apache.pig.data.SchemaTuple
 
setFloat(int, float) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setFragment(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
setFuncInputSchema() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
setFuncInputSchema(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
Sets EvalFunc's inputschema based on the signature
setFuncSpec(FuncSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
setFuncSpec(FuncSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
setFuncSpec(FuncSpec) - Method in class org.apache.pig.newplan.logical.expression.CastExpression
Set the FuncSpec that performs the casting functionality
setFuncSpec(FuncSpec) - Method in class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
setGlobalSort(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setGlobalSort(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
setGroupDisplayName(String) - Method in class org.apache.pig.tools.pigstats.spark.SparkCounterGroup
 
setGroupType(LOCogroup.GROUPTYPE) - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
 
setHeartBeat(boolean) - Method in class org.apache.pig.data.TimestampedTuple
 
setIdxFuncSpec(FuncSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
setIllustrator(Illustrator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
 
setIllustrator(Illustrator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setIllustrator(Illustrator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.JoinPackager
 
setIllustrator(Illustrator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
setIllustrator(Illustrator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
setIllustrator(Illustrator) - Method in interface org.apache.pig.pen.Illustrable
 
setImplementation(RegexImpl) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORegexp
 
setImplicitReferencedOperator(Operator) - Method in class org.apache.pig.newplan.logical.expression.ScalarExpression
 
setIn() - Static method in class org.apache.pig.tools.grunt.ConsoleReaderInputStream
 
setIn(ConsoleReader) - Static method in class org.apache.pig.tools.grunt.ConsoleReaderInputStream
 
setInCombiner(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
 
setInCombiner(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Sets a flag indicating if this operator is in a combiner.
setIndex(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
Sets the co-group index of this operator
setIndex(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setIndex(byte) - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
setIndex(byte) - Method in class org.apache.pig.impl.io.PigNullableWritable
 
setIndex(int) - Method in class org.apache.pig.LoadPushDown.RequiredField
 
setIndexFile(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
setIndexFile(String) - Method in class org.apache.pig.impl.builtin.DefaultIndexableLoader
 
setIndexFileName(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
setInitialized(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
setInitialized(boolean) - Static method in class org.apache.pig.impl.io.FileLocalizer
This method is only used by test code to reset state.
setInner(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.LitePackager
 
setInner(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
setInnerFlags(boolean[]) - Method in class org.apache.pig.newplan.logical.relational.LOCogroup
 
setInnerFlags(boolean[]) - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
setInnerPlan(LogicalPlan) - Method in class org.apache.pig.newplan.logical.relational.LOForEach
 
setInp(ArrayList<FileSpec>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.LoaderInfo
 
setInpLimits(ArrayList<Long>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.LoaderInfo
 
setInpSignatureLists(ArrayList<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.LoaderInfo
 
setInputArgsSchema(Schema) - Method in class org.apache.pig.FuncSpec
 
setInputAsExpr(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryExpressionOperator
Set the contained expression to the be the input value.
setInputAvroSchema(Schema) - Method in class org.apache.pig.builtin.AvroStorage
Sets the input avro schema to .
setInputAvroSchema(Set<Path>, Configuration) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
Set input avro schema.
setInputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBloomFilterRearrangeTez
 
setInputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
setInputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POIdentityInOutTez
 
setInputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POSimpleTezLoad
 
setInputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueInputTez
 
setInputKeys(List<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffleTezLoad
 
setInputNum(int) - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
setInputPlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.JoinPackager
 
setInputPlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
setInputs(List<PhysicalOperator>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setInputs(List<PhysicalOperator>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
 
setInputSchema(Schema) - Method in class org.apache.pig.EvalFunc
This method is for internal use.
setInputSpec(FileSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setInputSpec(StreamingCommand.HandleSpec) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Set the input specification for the StreamingCommand.
setInputSpec(FileSpec) - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
setInputSplitInfo(InputSplitInfo) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.LoaderInfo
 
setInstanceCapturingOutput(boolean) - Method in class org.apache.pig.scripting.ScriptingOutputCapturer
 
setInt(int, int) - Method in class org.apache.pig.data.SchemaTuple
 
setInt(int, int) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setInteractive(boolean) - Method in class org.apache.pig.tools.grunt.GruntParser
 
setIntermediateOutputKeyClass(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
setIntermediateOutputKeyComparatorClass(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
setIntermediateOutputValueClass(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
setIntermediateReducer(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setInvocationStack(List<PigParserNode.InvocationPoint>) - Method in class org.apache.pig.parser.PigParserNode
 
setIsDenseRank(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
Dense Rank flag
setIsDenseRank(boolean) - Method in class org.apache.pig.newplan.logical.relational.LORank
Set if it is a dense RANK BY
setIsRowNumber(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
Row number flag
setIsRowNumber(boolean) - Method in class org.apache.pig.newplan.logical.relational.LORank
Set if it is a simple RANK operation.
setIsTmpLoad(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
setIsTmpStore(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setJobException(Throwable) - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
setJobId(String) - Method in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
setJobName(String) - Method in class org.apache.pig.PigServer
Set the name of the job.
setJobPriority(String) - Method in class org.apache.pig.PigServer
Set Hadoop job priority.
setJobtrackerLocation(String) - Method in class org.apache.pig.impl.PigContext
 
setJoinPlans(MultiMap<PhysicalOperator, PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
setJoinPlans(MultiMap<Integer, LogicalExpressionPlan>) - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
setJoinType(LOJoin.JOINTYPE) - Method in class org.apache.pig.newplan.logical.relational.LOJoin
 
setKey(PigNullableWritable) - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
setKeyCompound(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
setKeyInfo(Map<Integer, Pair<Boolean, Map<Integer, Integer>>>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.CombinerPackager
 
setKeyInfo(Map<Integer, Pair<Boolean, Map<Integer, Integer>>>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
setKeyPlan(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
setKeyTuple(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
setKeyType(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
 
setKeyType(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
 
setKeyType(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
setKeyType(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
setKeyType(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
setKeyType(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
setKeyType(Class<?>) - Method in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
setKeyValueSeparator(String) - Method in class org.apache.pig.piggybank.storage.MultiStorage.MultiStorageOutputFormat
 
setLastAlias(String) - Method in class org.apache.pig.impl.PigContext
 
setLeafNode(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternNode
Set isLeafNode to true if the node must be a source
setLFile(FileSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
setLhs(ExpressionOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
setLhs(ExpressionOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
setLimit(long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
setLimit(long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
setLimit(long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
setLimit(long) - Method in class org.apache.pig.newplan.logical.relational.LOLimit
 
setLimit(long) - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
setLimit(long) - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
setLimit() - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
setLimitAfterSort(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setLimitOnly(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setLimitPlan(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
setLimitPlan(LogicalExpressionPlan) - Method in class org.apache.pig.newplan.logical.relational.LOLimit
 
setLoaderSignatures(List<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
setLoadFunc(LoadMetadata) - Method in class org.apache.pig.LoadFuncMetadataWrapper
The wrapped LoadMetadata object must be set before method calls are made on this object.
setLoadFunc(LoadFunc) - Method in class org.apache.pig.LoadFuncWrapper
The wrapped LoadFunc object must be set before method calls are made on this object.
setLoadOnly(boolean) - Method in class org.apache.pig.tools.grunt.GruntParser
 
setLoads(List<POLoad>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.LoaderInfo
 
setLocalCounter(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
setLocation(String, Job) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
setLocation(String, Job) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MergeJoinIndexer
 
setLocation(JobContext, POStore) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
Before delegating calls to underlying OutputFormat or OutputCommitter Pig needs to ensure the Configuration in the JobContext contains the output location and StoreFunc for the specific store - so set these up in the context for this specific store
setLocation(String, Job) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
setLocation(String, Job) - Method in class org.apache.pig.builtin.AvroStorage
 
setLocation(String, Job) - Method in class org.apache.pig.builtin.BinStorage
 
setLocation(String, Job) - Method in class org.apache.pig.builtin.JsonLoader
 
setLocation(String, Job) - Method in class org.apache.pig.builtin.mock.Storage
 
setLocation(String, Job) - Method in class org.apache.pig.builtin.OrcStorage
 
setLocation(String, Job) - Method in class org.apache.pig.builtin.ParquetLoader
 
setLocation(String, Job) - Method in class org.apache.pig.builtin.PigStorage
 
setLocation(String, Job) - Method in class org.apache.pig.builtin.TextLoader
 
setLocation(String, Job) - Method in class org.apache.pig.impl.builtin.DefaultIndexableLoader
 
setLocation(String, Job) - Method in class org.apache.pig.impl.builtin.SampleLoader
 
setLocation(String, Job) - Method in class org.apache.pig.impl.io.InterStorage
 
setLocation(String, Job) - Method in class org.apache.pig.impl.io.ReadToEndLoader
 
setLocation(String, Job) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
setLocation(String, Job) - Method in class org.apache.pig.impl.io.TFileStorage
 
setLocation(String, Job) - Method in class org.apache.pig.LoadFunc
Communicate to the loader the location of the object(s) being loaded.
setLocation(String, Job) - Method in class org.apache.pig.LoadFuncWrapper
 
setLocation(SourceLocation) - Method in class org.apache.pig.newplan.logical.relational.LOInnerLoad
 
setLocation(SourceLocation) - Method in class org.apache.pig.newplan.Operator
 
setLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.AllLoader
 
setLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
Set input location and obtain input schema.
setLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
setLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.CSVLoader
 
setLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.FixedWidthLoader
 
setLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
setLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.RegExLoader
 
setLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
setLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.XMLLoader
 
setLog4jProperties(Properties) - Method in class org.apache.pig.impl.PigContext
 
setLogDir(String) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Set the directory where the log-files of the command are persisted.
setLogFilesLimit(int) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Set the maximum number of tasks whose stderr logs files are persisted.
setLong(int, long) - Method in class org.apache.pig.data.SchemaTuple
 
setLong(int, long) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setLookUpKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
setMap(int, Map<String, Object>) - Method in class org.apache.pig.data.SchemaTuple
 
setMap(int, Map<String, Object>) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setMapDone(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setMapDoneMultiple(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setMapDoneSingle(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setMapKeysInfo(int, int, MapKeysInfo) - Method in class org.apache.pig.impl.plan.RequiredFields
Set a MapKeysInfo structure to the required map keys list
setMapKeysInfo(int, MapKeysInfo) - Method in class org.apache.pig.impl.plan.RequiredFields
Set the ith MapKeysInfo structure
setMappedFields(MultiMap<Integer, ProjectionMap.Column>) - Method in class org.apache.pig.impl.plan.ProjectionMap
 
setMapPlan(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
for local map/reduce simulation
setMapredCompressionCodecProps(Configuration) - Static method in class org.apache.pig.impl.util.Utils
 
setMapSideOnly(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
setMarkedAsShowToUser(boolean) - Method in exception org.apache.pig.PigException
Mark this exception as a good candidate for showing its message to the pig user
setMatch(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternNode
 
setMaxRecords(int) - Method in class org.apache.pig.pen.ExampleGenerator
 
setmBytes(Long) - Method in class org.apache.pig.ResourceStatistics
setMostCommonValues(Object[]) - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
setMostCommonValuesFreq(float[]) - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
setMSortFunc(POUserComparisonFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
setMultiInputs(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
Indicates this map has multiple input (such as the result of a join operation).
setMultiInputs(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
setMultiInputs(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
setMultiInputs(boolean) - Method in interface org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit
 
setMultiQueryIndex(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
Sets the multi-query index of this operator
setMultiStore(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setName(String) - Method in class org.apache.pig.Expression.Column
 
setName(String) - Method in class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
Set the name of the HandleSpec.
setName(String) - Method in class org.apache.pig.ResourceSchema.ResourceFieldSchema
Set the name of this filed.
setName(IRubyObject) - Method in class org.apache.pig.scripting.jruby.RubySchema
This method allows the user to set the name of the alias of the FieldSchema of the encapsulated Schema.
setNativeMRjar(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PONative
 
setNativeMRJar(String) - Method in class org.apache.pig.newplan.logical.relational.LONative
 
setNeedAllFields(boolean) - Method in class org.apache.pig.impl.plan.RequiredFields
 
setNeedEstimatedQuantile(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setNeedNoFields(boolean) - Method in class org.apache.pig.impl.plan.RequiredFields
 
setNeedsDistinctCombiner(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setNeedsDistinctCombiner(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
setNested(boolean) - Method in class org.apache.pig.newplan.logical.relational.LOCross
 
setNull(boolean) - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
setNull(boolean) - Method in class org.apache.pig.impl.io.PigNullableWritable
 
setNumDistinctValues(Long) - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
setNumInps(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
setNumInputs(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
setNumRecords(Long) - Method in class org.apache.pig.ResourceStatistics
 
setNumSamples(int) - Method in class org.apache.pig.impl.builtin.SampleLoader
 
setOperandType(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryComparisonOperator
 
setOperandType(byte) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
Set the type of the operand(s) of this comparator.
setOperandType(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryComparisonOperator
 
setOperationID(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
Operation ID: identifier shared within the corresponding PORank
setOperationID(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
Operation ID: identifier shared within the corresponding POCounter
setOperations(List<String>) - Method in class org.apache.pig.newplan.logical.relational.LOCube
 
setOpMap(MultiMap<PhysicalOperator, PhysicalOperator>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
setOpsToBeReset(List<PhysicalOperator>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
setOriginalLimit(long) - Method in class org.apache.pig.pen.Illustrator
 
setOutput(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
setOutputAvroSchema(Schema) - Method in class org.apache.pig.builtin.AvroStorage
Sets the output avro schema to .
setOutputBuffer(Map<String, DataBag>) - Method in class org.apache.pig.impl.builtin.ReadScalars
 
setOutputFormat(Job) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
setOutputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
setOutputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
setOutputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POStoreTez
 
setOutputPlans(List<LogicalExpressionPlan>) - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
setOutputPlanSchemas(List<LogicalSchema>) - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
setOutputSpec(StreamingCommand.HandleSpec) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Set the specification for the primary output of the StreamingCommand.
setOverloaded(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
setOverrideIntermediateParallelism(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setPackageImportList(ArrayList<String>) - Static method in class org.apache.pig.impl.PigContext
 
setPackageType(Packager.PackageType) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
setParamFiles(List<String>) - Method in class org.apache.pig.impl.PigContext
 
setParams(String[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PONative
 
setParams(List<String>) - Method in class org.apache.pig.impl.PigContext
 
setParams(String[]) - Method in class org.apache.pig.newplan.logical.relational.LONative
 
setParent(POPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
setParentPlan(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setPartition(int) - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
setPartitionFilter(Expression) - Method in class org.apache.pig.builtin.AvroStorage
 
setPartitionFilter(Expression) - Method in class org.apache.pig.builtin.BinStorage
 
setPartitionFilter(Expression) - Method in class org.apache.pig.builtin.JsonLoader
 
setPartitionFilter(Expression) - Method in class org.apache.pig.builtin.JsonMetadata
 
setPartitionFilter(Expression) - Method in class org.apache.pig.builtin.mock.Storage
 
setPartitionFilter(Expression) - Method in class org.apache.pig.builtin.OrcStorage
 
setPartitionFilter(Expression) - Method in class org.apache.pig.builtin.PigStorage
 
setPartitionFilter(Expression) - Method in class org.apache.pig.impl.io.InterStorage
 
setPartitionFilter(Expression) - Method in class org.apache.pig.impl.io.ReadToEndLoader
 
setPartitionFilter(Expression) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
setPartitionFilter(Expression) - Method in class org.apache.pig.impl.io.TFileStorage
 
setPartitionFilter(Expression) - Method in class org.apache.pig.LoadFuncMetadataWrapper
 
setPartitionFilter(Expression) - Method in interface org.apache.pig.LoadMetadata
Set the filter for partitioning.
setPartitionFilter(Expression) - Method in class org.apache.pig.piggybank.storage.AllLoader
 
setPartitionFilter(Expression) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
setPartitionFilter(Expression) - Method in class org.apache.pig.piggybank.storage.FixedWidthLoader
 
setPartitionFilter(Expression) - Method in class org.apache.pig.piggybank.storage.FixedWidthStorer
 
setPartitionFilter(Expression) - Method in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
setPartitionFilterExpression(String, Class<? extends LoadFunc>, String) - Method in class org.apache.pig.piggybank.storage.partition.PathPartitionHelper
Sets the PARITITION_FILTER_EXPRESSION property in the UDFContext identified by the loaderClass.
setPartitionKeys(String, Configuration, Class<? extends LoadFunc>, String) - Method in class org.apache.pig.piggybank.storage.partition.PathPartitionHelper
Reads the partition keys from the location i.e the base directory
setPc(PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
setPermission(FsPermission) - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
setPersistStderr(boolean) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Specify if the stderr of the managed process should be persisted.
setPigContext(PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartitionRearrange
 
setPigContext(PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezOperDependencyParallelismEstimator
 
setPigContext(PigContext) - Method in interface org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezParallelismEstimator
 
setPigContext(PigContext) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
setPigContext(PigContext) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
setPigContext(PigContext) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
 
setPigContext(PigContext) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
setPigLogger(PigLogger) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setPigLogger(PigLogger) - Method in class org.apache.pig.EvalFunc
Set the PigLogger object.
setPigStats(TezPigScriptStats) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
setPkgr(Packager) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
setPlan(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.UDFFinder
 
setPlan(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
 
setPlan(P) - Method in class org.apache.pig.impl.plan.PlanWalker
 
setPlan(PhysicalPlan, String) - Method in class org.apache.pig.impl.util.UDFContextSeparator
 
setPlan(OperatorPlan) - Method in class org.apache.pig.newplan.Operator
 
setPlan(OperatorPlan) - Method in class org.apache.pig.newplan.PlanWalker
Set the plan for this walker to operate on.
setPlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
setPlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
setPlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
setPlansFromCombiner(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
setPOStore(POStore) - Method in class org.apache.pig.tools.pigstats.OutputStats
 
setPredecessors(List<PhysicalOperator>) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POJoinGroupSpark
 
setProjectToEnd(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
setProperty(String, String) - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Responsible for setting a specific property and value.
setProperty(String, String) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
setPushdownPredicate(Expression) - Method in class org.apache.pig.builtin.OrcStorage
 
setPushdownPredicate(Expression) - Method in interface org.apache.pig.LoadPredicatePushdown
Push down expression to the loader
setQuantFile(String) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setR(Random) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
setRankColPlan(List<LogicalExpressionPlan>) - Method in class org.apache.pig.newplan.logical.relational.LORank
 
setRankPlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
setRawColumns(List<Object>) - Method in class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
setRecordDel(byte) - Method in class org.apache.pig.builtin.JsonMetadata
 
setRecords(long) - Method in class org.apache.pig.tools.pigstats.OutputStats
 
setReduceDone(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setReducePlan(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
Set the reduce plan: to be used by local runner for illustrator
setReferencedOperator(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
setRemovedFields(List<Pair<Integer, Integer>>) - Method in class org.apache.pig.impl.plan.ProjectionMap
 
setRep(TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ProgressableReporter
 
setReplFiles(FileSpec[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
setReplicatedInputs(Set<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.FRJoinConverter
 
setReporter(PigWarnCounter) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigHadoopLogger
 
setReporter(PigProgressable) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setReporter(PigProgressable) - Method in class org.apache.pig.ComparisonFunc
Deprecated.
Set the reporter.
setReporter(PigProgressable) - Method in class org.apache.pig.EvalFunc
Set the reporter.
setRequestedParallelism(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setRequestedParallelism(int) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
setRequestedParallelism(int) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setRequestedParallelism(int) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
setRequestedParallelismByReference(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
setRequestedParallelismByReference(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setRequiredFieldResponse(boolean) - Method in class org.apache.pig.LoadPushDown.RequiredFieldResponse
Set whether the loader will return only the requesetd fields or all fields.
setRequiredFields(List<Integer>) - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
setResultSingleTupleBag(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
setResultType(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
setResultType(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setRetriable(boolean) - Method in exception org.apache.pig.PigException
Set the retriable attribute of the exception
setReturnCode(int) - Method in class org.apache.pig.tools.pigstats.PigStats
 
setRhs(ExpressionOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
setRhs(ExpressionOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
setRightInputFileName(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
setRightLoaderFuncSpec(FuncSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
setSameMapKeyType(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.MultiQueryPackager
 
setSampleOperator(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setScalarOutput(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
setScan(Scan) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableRecordReader
 
setSchema(Schema) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setSchema(String, Schema) - Method in class org.apache.pig.builtin.mock.Storage.Data
to set the schema for a given location
setSchema(LogicalSchema) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
setSchema(ResourceSchema) - Method in class org.apache.pig.ResourceSchema.ResourceFieldSchema
Set the schema for this field.
setSchemaDefaultType(Schema, byte) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
Recursively set NULL type to the specifid type in a schema
setScript(File) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
setScript(String) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
setScript(BufferedReader) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
setScriptFeatures(LogicalPlan) - Method in class org.apache.pig.tools.pigstats.ScriptState
 
setScriptIllustrate() - Method in class org.apache.pig.tools.grunt.GruntParser
 
setScriptInfo(SparkOperPlan) - Method in class org.apache.pig.tools.pigstats.spark.SparkScriptState
 
setScriptSchema(LogicalSchema) - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
setSecondaryPlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
setSecondarySortOrder(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setSecondarySortOrder(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.IndexedKey
 
setSecondarySortOrder(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POGlobalRearrangeSpark
 
setSecondarySortOrder(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
setSecondarySortOrder(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
setSecondarySortOrder(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil.SecondaryKeyOptimizerInfo
 
setSFile(FileSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setSFile(FileSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
setShipFiles(List<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
setShipFiles(List<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
setShipFiles(List<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setShipFiles(boolean) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Set whether files should be shipped or not.
setSideFileSpecs(List<String>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
setSideLoadFuncs(List<FuncSpec>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
setSignature(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
setSignature(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
setSignature(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
setSignature(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setSizeInBytes(Long) - Method in class org.apache.pig.ResourceStatistics
Sets the size in bytes
setSkewedJoin(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setSkewedJoin(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
setSkewedJoinPartitionFile(String) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setSkewedJoinPartitionFile(String) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.SkewedJoinConverter
 
setSkewedJoinPartitionFile(String) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
setSkewedJoins(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffleTezLoad
 
setSkipIndices(List<Integer>) - Method in class org.apache.pig.piggybank.storage.MultiStorage.MultiStorageOutputFormat
 
setSkipListener(boolean) - Method in class org.apache.pig.newplan.optimizer.Rule
 
setSkipNullKeys(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POBuildBloomRearrangeTez
 
setSkipParseInRegisterForBatch(boolean) - Method in class org.apache.pig.PigServer
Set whether to skip parsing while registering the query in batch mode
setSortColPlans(List<LogicalExpressionPlan>) - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
setSortInfo(SortInfo) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setSortInfo(SortInfo) - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
setSortKeyOrders(ResourceSchema.Order[]) - Method in class org.apache.pig.ResourceSchema
Set the order for each sort key.
setSortKeys(int[]) - Method in class org.apache.pig.ResourceSchema
Set the sort keys for htis data.
setSortOperator(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setSortOrder(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setSortOrder(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setSortPlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
setSourceLocation(SourceLocation) - Method in exception org.apache.pig.PigException
 
setSourceNode(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternNode
Set isSourceNode to true if the node must be a source
setSparkUdfImportListStr(String) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkEngineConf
 
setSpec(String) - Method in class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
Set the serializer/deserializer spec of the HandleSpec.
setSpecific(T) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
setSpecific(T) - Method in class org.apache.pig.data.SchemaTuple
 
setSplitParent(OperatorKey) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setSplitStore(FileSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
Sets the name of the file associated with this operator
setSplitter(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setSplitter(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
setSplitter(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setStar(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
setStar(boolean) - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
setStartAlias(String) - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
setStartCol(int) - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
setStatsInputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.PORankTez
 
setStatsMap(Map<String, List<PigStats>>) - Static method in class org.apache.pig.tools.pigstats.PigStatsUtil
 
setStatsOutputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterTez
 
setStatus(String) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.IllustrateDummyReporter
 
setStatus(String) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRTaskContext
 
setStatus(String) - Method in class org.apache.pig.backend.hadoop.executionengine.TaskContext
 
setStatus(String) - Method in class org.apache.pig.tools.pigstats.PigStatusReporter
 
setStoreFunc(StoreFuncInterface) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setStoreFunc(StoreMetadata) - Method in class org.apache.pig.StoreFuncMetadataWrapper
The wrapped StoreMetadata object must be set before method calls are made on this object.
setStoreFunc(StoreFuncInterface) - Method in class org.apache.pig.StoreFuncWrapper
The wrapped StoreFuncInterface object must be set before method calls are made on this object.
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.builtin.AvroStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.builtin.BinStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.builtin.JsonStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.builtin.mock.Storage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.builtin.OrcStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.builtin.PigStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.impl.io.InterStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.impl.io.TFileStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.piggybank.storage.DBStorage
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.piggybank.storage.FixedWidthStorer
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.StoreFunc
This method will be called by Pig both in the front end and back end to pass a unique signature to the StoreFunc which it can use to store information in the UDFContext which it needs to store between various method invocations in the front end and back end.
setStoreFuncUDFContextSignature(String) - Method in interface org.apache.pig.StoreFuncInterface
This method will be called by Pig both in the front end and back end to pass a unique signature to the StoreFuncInterface which it can use to store information in the UDFContext which it needs to store between various method invocations in the front end and back end.
setStoreFuncUDFContextSignature(String) - Method in class org.apache.pig.StoreFuncWrapper
 
setStoreImpl(POStoreImpl) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setStoreLocation(String, Job) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.builtin.AvroStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.builtin.BinStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.builtin.JsonStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.builtin.mock.Storage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.builtin.OrcStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.builtin.ParquetStorer
Communicate to the storer the location where the data needs to be stored.
setStoreLocation(String, Job) - Method in class org.apache.pig.builtin.PigStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.impl.io.InterStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.impl.io.SequenceFileInterStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.impl.io.TFileStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.DBStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.FixedWidthStorer
 
setStoreLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.HiveColumnarStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.piggybank.storage.MultiStorage
 
setStoreLocation(String, Job) - Method in class org.apache.pig.StoreFunc
Communicate to the storer the location where the data needs to be stored.
setStoreLocation(String, Job) - Method in interface org.apache.pig.StoreFuncInterface
Communicate to the storer the location where the data needs to be stored.
setStoreLocation(String, Job) - Method in class org.apache.pig.StoreFuncWrapper
 
setStoreOutputDescriptor(OutputDescriptor) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
setString(int, String) - Method in class org.apache.pig.data.SchemaTuple
 
setString(int, String) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setStripKeyFromValue(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
setSubExpResult(boolean) - Method in class org.apache.pig.pen.Illustrator
 
setSubFields(List<LoadPushDown.RequiredField>) - Method in class org.apache.pig.LoadPushDown.RequiredField
 
setSuccessful(boolean) - Method in class org.apache.pig.tools.pigstats.JobStats
 
setSuccessful(boolean) - Method in class org.apache.pig.tools.pigstats.OutputStats
 
setTargetOps(List<OperatorKey>) - Method in class org.apache.pig.data.TargetedTuple
 
setTaskId(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
Task ID: identifier of the task (map or reducer)
setTaskIndexWithRecordIndexAsKey(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
setTimeStamp(double) - Method in class org.apache.pig.data.TimestampedTuple
 
setTimeToSleep(int) - Method in class org.apache.pig.backend.hadoop.PigJobControl
 
setTmpFileCompressionOnConf(PigContext, Configuration) - Static method in class org.apache.pig.impl.util.Utils
 
setTmpLoad(boolean) - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
setTmpStore(boolean) - Method in class org.apache.pig.newplan.logical.relational.LOStore
 
setToBeFlattened(List<Boolean>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.JoinPackager
 
setToBeFlattened(List<Boolean>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
setTotalInputFilesSize(long) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setTuple(int, Tuple) - Method in class org.apache.pig.data.SchemaTuple
 
setTuple(int, Tuple) - Method in interface org.apache.pig.data.TypeAwareTuple
 
setTupleIndex(int) - Static method in class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
This is a painful hack to make unit tests pass.
setTuplesInputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.PORankTez
 
setTuplesOutputKey(String) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterTez
 
setTwoLevelAccessRequired(boolean) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Deprecated.
twoLevelAccess is no longer needed
setType(byte) - Method in class org.apache.pig.LoadPushDown.RequiredField
 
setType(byte) - Method in class org.apache.pig.ResourceSchema.ResourceFieldSchema
Set the type of this field
setTypeAwareBase(int, Object, String) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
setTypeAwareBase(int, Object, String) - Method in class org.apache.pig.data.SchemaTuple
 
setUdfContext(UDFContext) - Static method in class org.apache.pig.impl.util.UDFContext
 
setUDFContextSignature(String) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
setUDFContextSignature(String) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
setUDFContextSignature(String) - Method in class org.apache.pig.builtin.AvroStorage
 
setUDFContextSignature(String) - Method in class org.apache.pig.builtin.JsonLoader
 
setUDFContextSignature(String) - Method in class org.apache.pig.builtin.mock.Storage
 
setUDFContextSignature(String) - Method in class org.apache.pig.builtin.OrcStorage
 
setUDFContextSignature(String) - Method in class org.apache.pig.builtin.PigStorage
 
setUDFContextSignature(String) - Method in class org.apache.pig.EvalFunc
This method will be called by Pig both in the front end and back end to pass a unique signature to the EvalFunc.
setUDFContextSignature(String) - Method in class org.apache.pig.impl.builtin.SampleLoader
 
setUDFContextSignature(String) - Method in class org.apache.pig.impl.io.ReadToEndLoader
 
setUDFContextSignature(String) - Method in class org.apache.pig.LoadFunc
This method will be called by Pig both in the front end and back end to pass a unique signature to the LoadFunc.
setUDFContextSignature(String) - Method in class org.apache.pig.LoadFuncWrapper
 
setUDFContextSignature(String) - Method in class org.apache.pig.piggybank.storage.AllLoader
 
setUDFContextSignature(String) - Method in class org.apache.pig.piggybank.storage.avro.AvroStorage
 
setUDFContextSignature(String) - Method in class org.apache.pig.piggybank.storage.CSVExcelStorage
 
setUDFContextSignature(String) - Method in class org.apache.pig.piggybank.storage.CSVLoader
 
setUDFContextSignature(String) - Method in class org.apache.pig.piggybank.storage.FixedWidthLoader
 
setUDFContextSignature(String) - Method in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
setUidOnlySchemas(List<LogicalSchema>) - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
setUnionOnSchema(boolean) - Method in class org.apache.pig.newplan.logical.relational.LOUnion
 
setup(Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.DistinctCombiner.Combine
 
setup(Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
Configures the Reduce plan, the POPackage operator and the reporter thread
setup(Mapper<Text, Tuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
Configures the mapper with the map plan and the reproter thread
setup(Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
Configures the Reduce plan, the POPackage operator and the reporter thread
setup(Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.ReduceWithComparator
Configures the Reduce plan, the POPackage operator and the reporter thread
setup(Mapper<Text, Tuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter.PigMapCounter
Here is set up the task id, in order to be attached to each tuple
setup(Reducer<PigNullableWritable, NullableTuple, PigNullableWritable, Writable>.Context) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter.PigReduceCounter
Here is set up the task id, in order to be attached to each tuple
setUp - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
setUp() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
Set up the loader by 1) Instantiating the load func 2) Opening an input stream to the specified file and 3) Binding to the input stream at the specified offset.
setUp() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
Set up the storer
setupAvailableZoneIds() - Static method in class org.apache.pig.backend.hadoop.DateTimeWritable
 
setupColNameMaps() - Method in class org.apache.pig.newplan.logical.rules.PartitionFilterOptimizer.PartitionFilterPushDownTransformer
 
setUpContext(JobContext, POStore) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
setUpFlattens(List<Boolean>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
setUpHashMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
Builds the HashMaps by reading each replicated input from the DFS using a Load operator
setUpHashMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoinSpark
 
setUpHashMap() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POFRJoinTez
Builds the HashMaps by reading replicated inputs from broadcast edges
setupJob(JobContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
setupJob(JobContext) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigOutputFormatTez.PigOutputCommitterTez
 
setupRightPipeline(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
setupStreamingDirsConfMulti(PigContext, Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
Sets up output and log dir paths for a multi-store streaming job
setupStreamingDirsConfSingle(POStore, PigContext, Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
Sets up output and log dir paths for a single-store streaming job
setupTask(TaskAttemptContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
setupUDFContext(Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
 
setupUdfEnvAndStores(JobContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
 
setUseGraceParallelism(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setUseMRMapSettings(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setUserDefinedSchema(List<LogicalSchema>) - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
setUserFunc(FuncSpec) - Method in class org.apache.pig.newplan.logical.relational.LOSort
 
setUseSecondaryKey(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setUseSecondaryKey(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
setUseSecondaryKey(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
setUseSecondaryKey(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.IndexedKey
 
setUseSecondaryKey(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POGlobalRearrangeSpark
 
setUseSecondaryKey(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POReduceBySpark
 
setUseSecondaryKey(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
setUseSecondaryKey(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setUseSecondaryKey(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.util.SecondaryKeyOptimizerUtil.SecondaryKeyOptimizerInfo
 
setValidateEachStatement(boolean) - Method in class org.apache.pig.PigServer
This can be called to indicate if the query is being parsed/compiled in a mode that expects each statement to be validated as it is entered, instead of just doing it once for whole script.
setValidateEachStatement(boolean) - Method in class org.apache.pig.tools.grunt.GruntParser
 
setValue(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
setValue(Object) - Method in class org.apache.pig.newplan.logical.expression.ConstantExpression
 
setValueHistogram(Object[]) - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
setValuePlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
setValueType(Class<?>) - Method in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
setVerbose(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter
 
setVerbose(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.MRPrinter
 
setVerbose(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
setVerbose(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter
 
setVerbose(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkPrinter
 
setVerbose(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerPrinter
 
setVerbose(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPrinter
 
setVerbose(boolean) - Method in class org.apache.pig.impl.plan.PlanDumper
 
setVerbose(boolean) - Method in class org.apache.pig.newplan.PlanDumper
 
setVersion(int) - Method in class org.apache.pig.ResourceSchema
 
setVersion(int) - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
setVertexConfig(Vertex, boolean, Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.MRToTezHelper
Set config with Scope.Vertex in TezConfiguration on the vertex
setVertexGroup(VertexGroup) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
setVertexGroupInfo(TezOperator.VertexGroupInfo) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setVertexGroupMembers(List<OperatorKey>) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setVertexParallelism(int) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
setXMLIdentifier(String) - Method in class org.apache.pig.piggybank.storage.XMLLoader.XMLRecordReader
 
shallowClone() - Method in class org.apache.pig.newplan.PlanEdge
 
SHOULD_USE_SCHEMA_TUPLE - Static variable in class org.apache.pig.PigConfiguration
Deprecated.
shouldDisableDAGRecovery() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezDagBuilder
 
shouldGenerate(Class) - Method in enum org.apache.pig.data.SchemaTupleClassGenerator.GenContext
Checks the generated class to see if the annotation associated with this enum is present.
shouldGenerate(Configuration) - Method in enum org.apache.pig.data.SchemaTupleClassGenerator.GenContext
Given a job configuration file, this checks to see if the default value has been overriden.
shouldOverwrite() - Method in class org.apache.pig.builtin.PigStorage
 
shouldOverwrite() - Method in interface org.apache.pig.OverwritableStoreFunc
This method is called by the Pig runtime to determine whether to ignore output validation problems (see PigOutputFormat.checkOutputSpecs(org.apache.hadoop.mapreduce.JobContext) and InputOutputFileValidator#validate) and to delete the existing output.
shutdown() - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.TezSessionManager
 
shutdown() - Method in class org.apache.pig.PigServer
Reclaims resources used by this instance of PigServer.
SHUTDOWN_HOOK_ATS_CLIENT_PRIORITY - Static variable in class org.apache.pig.impl.PigImplConstants
 
SHUTDOWN_HOOK_JOB_KILL_PRIORITY - Static variable in class org.apache.pig.impl.PigImplConstants
 
SHUTDOWN_HOOK_TMP_FILES_CLEANUP_PRIORITY - Static variable in class org.apache.pig.impl.PigImplConstants
 
signature - Variable in class org.apache.pig.builtin.PigStorage
 
SIGNUM - Class in org.apache.pig.piggybank.evaluation.math
math.SIGNUM implements a binding to the Java function Math.signum(double).
SIGNUM() - Constructor for class org.apache.pig.piggybank.evaluation.math.SIGNUM
 
simpleConnectMapToReduce(MapReduceOper, String, NodeIdGenerator) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRUtil
 
simpleConnectTwoVertex(TezOperPlan, TezOperator, TezOperator, String, NodeIdGenerator) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
SimplePigStats - Class in org.apache.pig.tools.pigstats.mapreduce
SimplePigStats encapsulates the statistics collected from a running script.
SimplePigStats() - Constructor for class org.apache.pig.tools.pigstats.mapreduce.SimplePigStats
 
simpleUnset(Configuration, Map<String, String>) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
Unsets elements in the Configuration using the unset method
SIN - Class in org.apache.pig.builtin
SIN implements a binding to the Java function Math.sin(double).
SIN() - Constructor for class org.apache.pig.builtin.SIN
 
SIN - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use SIN
SIN() - Constructor for class org.apache.pig.piggybank.evaluation.math.SIN
Deprecated.
 
SingleTupleBag - Class in org.apache.pig.data
A simple performant implementation of the DataBag interface which only holds a single tuple.
SingleTupleBag(Tuple) - Constructor for class org.apache.pig.data.SingleTupleBag
 
SINH - Class in org.apache.pig.builtin
SINH implements a binding to the Java function Math.sinh(double).
SINH() - Constructor for class org.apache.pig.builtin.SINH
 
SINH - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use SINH
SINH() - Constructor for class org.apache.pig.piggybank.evaluation.math.SINH
Deprecated.
 
size() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnChainInfo
 
size() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin.TuplesToSchemaTupleList
 
SIZE - Class in org.apache.pig.builtin
Generates the size of the argument passed to it.
SIZE() - Constructor for class org.apache.pig.builtin.SIZE
 
size() - Method in class org.apache.pig.data.AccumulativeBag
 
size() - Method in class org.apache.pig.data.AppendableSchemaTuple
 
size() - Method in interface org.apache.pig.data.DataBag
Get the number of elements in the bag, both in memory and on disk.
size() - Method in class org.apache.pig.data.DataByteArray
Find the size of the byte array.
size() - Method in class org.apache.pig.data.DefaultAbstractBag
Get the number of elements in the bag, both in memory and on disk.
size() - Method in class org.apache.pig.data.DefaultTuple
Find the size of the tuple.
size() - Method in class org.apache.pig.data.DistinctDataBag
 
size() - Method in class org.apache.pig.data.InternalDistinctBag
 
size() - Method in class org.apache.pig.data.LimitedSortedDataBag
Get the number of elements in the bag in memory.
size() - Method in class org.apache.pig.data.NonSpillableDataBag
 
size() - Method in class org.apache.pig.data.ReadOnceBag
 
size() - Method in class org.apache.pig.data.SchemaTuple
 
size() - Method in class org.apache.pig.data.SingleTupleBag
 
size() - Method in class org.apache.pig.data.TargetedTuple
 
size() - Method in interface org.apache.pig.data.Tuple
Find the size of the tuple.
size() - Method in class org.apache.pig.data.UnlimitedNullTuple
 
size() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Find the number of fields in the schema.
size() - Method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
size() - Method in class org.apache.pig.impl.plan.OperatorPlan
 
size() - Method in class org.apache.pig.impl.plan.RequiredFields
 
size() - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
size() - Method in class org.apache.pig.impl.util.avro.AvroMapWrapper
 
size() - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
size() - Method in class org.apache.pig.impl.util.IdentityHashSet
 
size() - Method in class org.apache.pig.impl.util.MultiMap
Get the number of keys in the map.
size() - Method in class org.apache.pig.newplan.BaseOperatorPlan
Get number of nodes in the plan.
size() - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
Get the size of the schema.
size() - Method in interface org.apache.pig.newplan.OperatorPlan
Get number of nodes in the plan.
size() - Method in class org.apache.pig.newplan.OperatorSubPlan
 
size() - Method in class org.apache.pig.pen.util.ExampleTuple
 
size(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubyDataBag
This returns the size of the encapsulated DataBag.
size(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubyDataByteArray
 
size(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubySchema
 
SizeUtil - Class in org.apache.pig.data
Utility functions for estimating size of objects of pig types
SizeUtil() - Constructor for class org.apache.pig.data.SizeUtil
 
sJobConf - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce
Deprecated.
Use UDFContext instead in the following way to get the job's Configuration:
UdfContext.getUdfContext().getJobConf()
sJobConfInternal - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce
 
sJobContext - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce
 
SkewedJoinConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
SkewedJoinConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.SkewedJoinConverter
 
SkewedPartitioner - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners
This class is used by skewed join.
SkewedPartitioner() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SkewedPartitioner
 
SkewedPartitionerTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.runtime
 
SkewedPartitionerTez() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.runtime.SkewedPartitionerTez
 
skip(long) - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
skip(long) - Method in class org.apache.pig.impl.io.BufferedPositionedInputStream
 
skip(long) - Method in class org.apache.pig.impl.io.FileLocalizer.DataStorageInputStreamIterator
 
skipInterval - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
skipNext() - Method in class org.apache.pig.impl.builtin.SampleLoader
 
slashisize(String) - Static method in class org.apache.pig.impl.util.Utils
Replace sequences of two slashes ("\\") with one slash ("\") (not escaping a slash in grunt is disallowed, but a double slash doesn't get converted into a regular slash, so we have to do it instead)
SMALL_JOB_LOG_MSG - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
SMALLBAG - Static variable in class org.apache.pig.data.BinInterSedes
 
SMALLBYTEARRAY - Static variable in class org.apache.pig.data.BinInterSedes
 
SMALLCHARARRAY - Static variable in class org.apache.pig.data.BinInterSedes
 
SMALLMAP - Static variable in class org.apache.pig.data.BinInterSedes
 
SMALLTUPLE - Static variable in class org.apache.pig.data.BinInterSedes
 
softFromEdges - Variable in class org.apache.pig.newplan.BaseOperatorPlan
 
softToEdges - Variable in class org.apache.pig.newplan.BaseOperatorPlan
 
sopen(Properties) - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
Open an element in the Data Storage with support for random access (seek operations).
sopen() - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
 
sopen(Properties) - Method in class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
sopen() - Method in class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
sopen(Properties) - Method in class org.apache.pig.backend.hadoop.datastorage.HFile
 
sopen() - Method in class org.apache.pig.backend.hadoop.datastorage.HFile
 
sopen() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
SORT_VERTEX - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.runtime.PigProcessor
 
SortColInfo - Class in org.apache.pig
A class representing information about a sort column in SortInfo
SortColInfo(String, int, SortColInfo.Order) - Constructor for class org.apache.pig.SortColInfo
 
SortColInfo.Order - Enum in org.apache.pig
 
SortComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort.SortComparator
 
SortConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
SortConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.SortConverter
 
SortedDataBag - Class in org.apache.pig.data
An ordered collection of Tuples (possibly) with multiples.
SortedDataBag(Comparator<Tuple>) - Constructor for class org.apache.pig.data.SortedDataBag
 
SortedSpillBag - Class in org.apache.pig.data
Common functionality for proactively spilling bags that need to keep the data sorted.
SortInfo - Class in org.apache.pig
Class to communicate sort column information based on order by statment's sort columns and schema
SortInfo(List<SortColInfo>) - Constructor for class org.apache.pig.SortInfo
 
SortInfoSetter - Class in org.apache.pig.newplan.logical.visitor
 
SortInfoSetter(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.SortInfoSetter
 
SortKeyInfo - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
SortKeyInfo() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SortKeyInfo
 
sourceIsBag() - Method in class org.apache.pig.newplan.logical.relational.LOInnerLoad
 
SourceLocation - Class in org.apache.pig.parser
 
SourceLocation() - Constructor for class org.apache.pig.parser.SourceLocation
 
SourceLocation(String, int, int) - Constructor for class org.apache.pig.parser.SourceLocation
 
SourceLocation(PigParserNode) - Constructor for class org.apache.pig.parser.SourceLocation
 
SourceLocation(SourceLocation) - Constructor for class org.apache.pig.parser.SourceLocation
 
sourceLocation - Variable in exception org.apache.pig.PigException
 
SPARK_INPUT_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
SPARK_INPUT_RECORD_COUNTER - Static variable in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
SPARK_STORE_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
SPARK_STORE_RECORD_COUNTER - Static variable in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
SparkCompiler - Class in org.apache.pig.backend.hadoop.executionengine.spark.plan
The compiler that compiles a given physical physicalPlan into a DAG of Spark operators
SparkCompiler(PhysicalPlan, PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
SparkCompilerException - Exception in org.apache.pig.backend.hadoop.executionengine.spark.plan
Create a new SparkCompilerException with null as the error message.
SparkCompilerException() - Constructor for exception org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompilerException
Create a new SparkCompilerException with null as the error message.
SparkCompilerException(String) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompilerException
Create a new SparkCompilerException with the specified message and cause.
SparkCompilerException(Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompilerException
Create a new SparkCompilerException with the specified cause.
SparkCompilerException(String, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompilerException
Create a new SparkCompilerException with the specified message and cause.
SparkCompilerException(String, int) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompilerException
Create a new SparkCompilerException with the specified message and cause.
SparkCompilerException(String, int, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompilerException
Create a new SparkCompilerException with the specified message and cause.
SparkCompilerException(String, int, byte) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompilerException
Create a new SparkCompilerException with the specified message and cause.
SparkCompilerException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompilerException
Create a new SparkCompilerException with the specified message and cause.
SparkCompilerException(String, int, boolean) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompilerException
Create a new SparkCompilerException with the specified message and cause.
SparkCompilerException(String, int, byte, boolean) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompilerException
Create a new SparkCompilerException with the specified message and cause.
SparkCompilerException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompilerException
Create a new SparkCompilerException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
SparkCompilerException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompilerException
Create a new SparkCompilerException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
SparkCounter<T> - Class in org.apache.pig.tools.pigstats.spark
 
SparkCounter() - Constructor for class org.apache.pig.tools.pigstats.spark.SparkCounter
 
SparkCounter(String, String, String, T, JavaSparkContext) - Constructor for class org.apache.pig.tools.pigstats.spark.SparkCounter
 
SparkCounter.LongSparkCounter - Class in org.apache.pig.tools.pigstats.spark
 
SparkCounter.MapSparkCounter - Class in org.apache.pig.tools.pigstats.spark
 
SparkCounterGroup<T> - Class in org.apache.pig.tools.pigstats.spark
 
SparkCounterGroup(String, String, JavaSparkContext) - Constructor for class org.apache.pig.tools.pigstats.spark.SparkCounterGroup
 
SparkCounterGroup.LongSparkCounterGroup - Class in org.apache.pig.tools.pigstats.spark
 
SparkCounterGroup.MapSparkCounterGroup - Class in org.apache.pig.tools.pigstats.spark
 
sparkCounters - Variable in class org.apache.pig.tools.pigstats.spark.SparkCounterGroup
 
SparkCounters - Class in org.apache.pig.tools.pigstats.spark
 
SparkCounters(JavaSparkContext) - Constructor for class org.apache.pig.tools.pigstats.spark.SparkCounters
 
SparkEngineConf - Class in org.apache.pig.backend.hadoop.executionengine.spark
The object of SparkEngineConf is to solve the initialization problem of PigContext.properties.get("udf.import.list"), UDFContext#udfConfs, UDFContext#clientSysProps in spark mode.
SparkEngineConf() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkEngineConf
 
SparkExecType - Class in org.apache.pig.backend.hadoop.executionengine.spark
 
SparkExecType() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkExecType
 
SparkExecutableManager - Class in org.apache.pig.backend.hadoop.executionengine.spark.streaming
 
SparkExecutableManager() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.streaming.SparkExecutableManager
 
SparkExecutionEngine - Class in org.apache.pig.backend.hadoop.executionengine.spark
 
SparkExecutionEngine(PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkExecutionEngine
 
SparkJobStats - Class in org.apache.pig.tools.pigstats.spark
 
SparkJobStats(int, PigStats.JobGraph, Configuration) - Constructor for class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
SparkJobStats(String, PigStats.JobGraph, Configuration) - Constructor for class org.apache.pig.tools.pigstats.spark.SparkJobStats
 
SparkLauncher - Class in org.apache.pig.backend.hadoop.executionengine.spark
Main class that launches pig for Spark
SparkLauncher() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkLauncher
 
SparkLauncher.ResourceType - Enum in org.apache.pig.backend.hadoop.executionengine.spark
 
SparkLocalExecType - Class in org.apache.pig.backend.hadoop.executionengine.spark
SparkLocalExecType is the ExecType for local mode in Spark.
SparkLocalExecType() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkLocalExecType
 
SparkOperator - Class in org.apache.pig.backend.hadoop.executionengine.spark.plan
An operator model for a Spark job.
SparkOperator(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
SparkOperPlan - Class in org.apache.pig.backend.hadoop.executionengine.spark.plan
A Plan used to create the physicalPlan of Spark Operators
SparkOperPlan() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperPlan
 
SparkOpPlanVisitor - Class in org.apache.pig.backend.hadoop.executionengine.spark.plan
A visitor for the SparkOperPlan class
SparkOpPlanVisitor(SparkOperPlan, PlanWalker<SparkOperator, SparkOperPlan>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOpPlanVisitor
 
SparkPigContext - Class in org.apache.pig.backend.hadoop.executionengine.spark
singleton class like PigContext
SparkPigContext() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigContext
 
SparkPigRecordReader - Class in org.apache.pig.backend.hadoop.executionengine.spark
Record reader for Spark mode - handles SparkPigSplit
SparkPigRecordReader(InputFormat<?, ?>, PigSplit, LoadFunc, TaskAttemptContext, long) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigRecordReader
 
SparkPigSplit - Interface in org.apache.pig.backend.hadoop.executionengine.spark
Wrapper class for PigSplits in Spark mode Spark only counts HDFS bytes read if we provide a FileSplit, so we have to wrap PigSplits and have the wrapper class extend FileSplit
SparkPigSplit.FileSparkPigSplit - Class in org.apache.pig.backend.hadoop.executionengine.spark
 
SparkPigSplit.GenericSparkPigSplit - Class in org.apache.pig.backend.hadoop.executionengine.spark
 
SparkPigStats - Class in org.apache.pig.tools.pigstats.spark
 
SparkPigStats() - Constructor for class org.apache.pig.tools.pigstats.spark.SparkPigStats
 
SparkPigStatusReporter - Class in org.apache.pig.tools.pigstats.spark
Just like PigStatusReporter which will create/reset Hadoop counters, SparkPigStatusReporter will create/reset Spark counters.
SparkPOPackageAnnotator - Class in org.apache.pig.backend.hadoop.executionengine.spark.plan
This visitor visits the SparkPlan and does the following for each SparkOperator - visits the POPackage in the plan and finds the corresponding POLocalRearrange(s).
SparkPOPackageAnnotator(SparkOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkPOPackageAnnotator
 
SparkPOUserFuncVisitor - Class in org.apache.pig.backend.hadoop.executionengine.spark
 
SparkPOUserFuncVisitor(SparkOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkPOUserFuncVisitor
 
SparkPrinter - Class in org.apache.pig.backend.hadoop.executionengine.spark.plan
A visitor mechanism printing out the logical plan.
SparkPrinter(PrintStream, SparkOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkPrinter
 
SparkSampleSortConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
SparkSampleSortConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.SparkSampleSortConverter
 
SparkScriptInfo(SparkOperPlan) - Constructor for class org.apache.pig.tools.pigstats.spark.SparkScriptState.SparkScriptInfo
 
SparkScriptState - Class in org.apache.pig.tools.pigstats.spark
ScriptStates encapsulates settings for a Pig script that runs on a hadoop cluster.
SparkScriptState(String) - Constructor for class org.apache.pig.tools.pigstats.spark.SparkScriptState
 
SparkScriptState.SparkScriptInfo - Class in org.apache.pig.tools.pigstats.spark
 
SparkSecondaryKeyOptimizerUtil - Class in org.apache.pig.backend.hadoop.executionengine.spark.optimizer
 
SparkSecondaryKeyOptimizerUtil() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.SparkSecondaryKeyOptimizerUtil
 
SparkStatsUtil - Class in org.apache.pig.tools.pigstats.spark
 
SparkStatsUtil() - Constructor for class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
SparkUtil - Class in org.apache.pig.backend.hadoop.executionengine.spark
 
SparkUtil() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.SparkUtil
 
spawnChildWalker(P) - Method in class org.apache.pig.impl.plan.DependencyOrderWalker
 
spawnChildWalker(P) - Method in class org.apache.pig.impl.plan.DepthFirstWalker
 
spawnChildWalker(P) - Method in class org.apache.pig.impl.plan.PlanWalker
Return a new instance of this same type of walker for a subplan.
spawnChildWalker(P) - Method in class org.apache.pig.impl.plan.ReverseDependencyOrderWalker
 
spawnChildWalker(OperatorPlan) - Method in class org.apache.pig.newplan.DependencyOrderWalker
 
spawnChildWalker(OperatorPlan) - Method in class org.apache.pig.newplan.DepthFirstWalker
 
spawnChildWalker(OperatorPlan) - Method in class org.apache.pig.newplan.PlanWalker
Return a new instance of this same type of walker for a subplan.
spawnChildWalker(OperatorPlan) - Method in class org.apache.pig.newplan.ReverseDependencyOrderWalker
 
spawnChildWalker(OperatorPlan) - Method in class org.apache.pig.newplan.ReverseDependencyOrderWalkerWOSeenChk
 
spawnChildWalker(OperatorPlan) - Method in class org.apache.pig.pen.util.PreOrderDepthFirstWalker
 
spill() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
spill() - Method in class org.apache.pig.data.AccumulativeBag
 
spill() - Method in class org.apache.pig.data.DefaultDataBag
 
spill() - Method in class org.apache.pig.data.DistinctDataBag
 
spill() - Method in class org.apache.pig.data.InternalCachedBag
 
spill() - Method in class org.apache.pig.data.InternalDistinctBag
 
spill() - Method in class org.apache.pig.data.InternalSortedBag
 
spill() - Method in class org.apache.pig.data.LimitedSortedDataBag
Not implemented.
spill() - Method in class org.apache.pig.data.NonSpillableDataBag
 
spill() - Method in class org.apache.pig.data.ReadOnceBag
 
spill() - Method in class org.apache.pig.data.SingleTupleBag
 
spill() - Method in class org.apache.pig.data.SortedDataBag
 
spill() - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
spill() - Method in interface org.apache.pig.impl.util.Spillable
Instructs an object to spill whatever it can to disk and release references to any data structures it spills.
Spillable - Interface in org.apache.pig.impl.util
 
SpillableMemoryManager - Class in org.apache.pig.impl.util
This class Tracks the tenured pool and a list of Spillable objects.
spillTupleContents(Tuple, String) - Static method in class org.apache.pig.data.DataType
Purely for debugging
split(TezPlanContainerNode) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainer
 
Split - Class in org.apache.pig.piggybank.evaluation.string
Deprecated.
Split() - Constructor for class org.apache.pig.piggybank.evaluation.string.Split
Deprecated.
 
SplitConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
SplitConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.SplitConverter
 
SplitFilter - Class in org.apache.pig.newplan.logical.rules
 
SplitFilter(String) - Constructor for class org.apache.pig.newplan.logical.rules.SplitFilter
 
SplitFilter.SplitFilterTransformer - Class in org.apache.pig.newplan.logical.rules
 
SplitFilterTransformer() - Constructor for class org.apache.pig.newplan.logical.rules.SplitFilter.SplitFilterTransformer
 
SPRINTF - Class in org.apache.pig.builtin
Formatted strings using java.util.Formatter See http://docs.oracle.com/javase/7/docs/api/java/util/Formatter.html ex: SPRINTF('%2$10s %1$-17s %2$,10d %2$8x %3$10.3f %4$1TFT%
SPRINTF() - Constructor for class org.apache.pig.builtin.SPRINTF
 
sql(String) - Static method in class org.apache.pig.scripting.Pig
Run a sql command.
sqlDataTypeFromPigDataType(byte) - Method in class org.apache.pig.piggybank.storage.DBStorage
 
SQRT - Class in org.apache.pig.builtin
SQRT implements a binding to the Java function Math.sqrt(double).
SQRT() - Constructor for class org.apache.pig.builtin.SQRT
 
SQRT - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use SQRT
SQRT() - Constructor for class org.apache.pig.piggybank.evaluation.math.SQRT
Deprecated.
 
stage - Variable in class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.AlgebraicFunctionWrapper
 
stampFieldSchema() - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
Give new value for uid if uid of field schema or those in fields schema of inner schema are -1.
starMarkup(Tuple, Tuple, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager
 
start - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
start() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
start(PigStats) - Static method in class org.apache.pig.tools.pigstats.PigStats
 
start() - Method in class org.apache.pig.tools.pigstats.PigStats
 
start(ScriptState) - Static method in class org.apache.pig.tools.pigstats.ScriptState
 
start(String, PigContext) - Static method in class org.apache.pig.tools.pigstats.ScriptState
Deprecated.
start() - Method in class org.apache.pig.tools.timer.PerformanceTimer
Start the timer.
START_ROW_OPTION - Static variable in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
startBag - Static variable in class org.apache.pig.data.DefaultAbstractBag
 
StartBag() - Constructor for class org.apache.pig.data.DefaultAbstractBag.StartBag
 
startCapturingOutput() - Static method in class org.apache.pig.scripting.ScriptingOutputCapturer
 
startCol - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
startCollection(PigContext, JobClient, JobControlCompiler, MROperPlan) - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
Starts collecting statistics for the given MR plan
STARTSWITH - Class in org.apache.pig.builtin
Pig UDF to test input tuple.get(0) against tuple.get(1) to determine if the first argument starts with the string in the second.
STARTSWITH() - Constructor for class org.apache.pig.builtin.STARTSWITH
 
startTime - Variable in class org.apache.pig.tools.pigstats.PigStats
 
state - Variable in class org.apache.pig.tools.pigstats.JobStats
 
staticDataCleanup() - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.DistinctCombiner.Combine
 
staticDataCleanup() - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
 
staticDataCleanup() - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce
 
staticDataCleanup() - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
staticDataCleanup() - Static method in class org.apache.pig.impl.PigContext
 
staticDataCleanup() - Static method in class org.apache.pig.impl.util.SpillableMemoryManager
 
staticDataCleanup() - Static method in class org.apache.pig.impl.util.UDFContext
 
StaticDataCleanup - Annotation Type in org.apache.pig
 
staticDataCleanup() - Static method in class org.apache.pig.tools.pigstats.PigStatusReporter
 
staticDataCleanup() - Static method in class org.apache.pig.tools.pigstats.spark.SparkPigStatusReporter
 
staticSchemaGen(String) - Static method in class org.apache.pig.data.SchemaTuple
 
status - Variable in class org.apache.pig.backend.hadoop.executionengine.HJob
 
STATUS_BATCH_OK - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
Successful processing of a batch.
STATUS_EARLY_TERMINATION - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
This signals that an accumulative UDF has already finished.
STATUS_EOP - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
STATUS_EOP indicates that no output was produced, and no further outputs will be produced (e.g.
STATUS_EOS - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
This is currently only used in communications between ExecutableManager and POStream.
STATUS_ERR - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
STATUS_ERR indicates that there was a problem while trying to produce a result.
STATUS_NULL - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
STATUS_NULL indicates that no output was produced, but there may be more results.
STATUS_OK - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
STATUS_OK indicates that the pull on the operator pipeline resulted in a valid output.
stdin - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
Stitch - Class in org.apache.pig.piggybank.evaluation
Given a set of bags, stitch them together tuple by tuple.
Stitch() - Constructor for class org.apache.pig.piggybank.evaluation.Stitch
 
stop() - Method in class org.apache.pig.tools.pigstats.EmptyPigStats
 
stop() - Method in class org.apache.pig.tools.pigstats.PigStats
 
stop() - Method in class org.apache.pig.tools.timer.PerformanceTimer
Stop the timer.
stopCollection(boolean) - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
Stops collecting statistics for a MR plan
Storage - Class in org.apache.pig.builtin.mock
A convenient mock Storage for unit tests
Storage() - Constructor for class org.apache.pig.builtin.mock.Storage
 
Storage.Data - Class in org.apache.pig.builtin.mock
An isolated data store to avoid side effects
storageOptions - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
StorageUtil - Class in org.apache.pig.impl.util
This util class provides methods that are shared by storage class PigStorage and streaming class PigStreaming
StorageUtil() - Constructor for class org.apache.pig.impl.util.StorageUtil
 
store(DataBag, FuncSpec, PigContext) - Method in class org.apache.pig.impl.io.PigFile
 
store(String, String) - Method in class org.apache.pig.PigServer
Executes a Pig Latin script up to and including indicated alias and stores the resulting records into a file.
store(String, String, String) - Method in class org.apache.pig.PigServer
Executes a Pig Latin script up to and including indicated alias and stores the resulting records into a file.
StoreAliasSetter - Class in org.apache.pig.newplan.logical.visitor
 
StoreAliasSetter(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.StoreAliasSetter
 
StoreCaster - Interface in org.apache.pig
An interface that provides methods for converting Pig internal types to byte[].
storeCleanup(POStore, Configuration) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputCommitter
 
StoreConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
Converter that takes a POStore and stores it's content.
StoreConverter(JobConf) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.StoreConverter
 
StoreFunc - Class in org.apache.pig
StoreFuncs take records from Pig's processing and store them into a data store.
StoreFunc() - Constructor for class org.apache.pig.StoreFunc
 
StoreFuncDecorator - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
This class is used to decorate the StoreFunc#putNext(Tuple).
StoreFuncDecorator(StoreFuncInterface, String) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.StoreFuncDecorator
 
StoreFuncInterface - Interface in org.apache.pig
StoreFuncs take records from Pig's processing and store them into a data store.
StoreFuncMetadataWrapper - Class in org.apache.pig
Convenience class to extend when decorating a class that implements both StoreFunc and StoreMetadata.
StoreFuncMetadataWrapper() - Constructor for class org.apache.pig.StoreFuncMetadataWrapper
 
StoreFuncWrapper - Class in org.apache.pig
Convenience class to extend when decorating a StoreFunc.
StoreFuncWrapper() - Constructor for class org.apache.pig.StoreFuncWrapper
 
StoreMetadata - Interface in org.apache.pig
This interface defines how to write metadata related to data to be stored.
storeProjectedFieldNames(LoadPushDown.RequiredFieldList) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
Stores the requiredFieldsList as a serialized object so it can be fetched on the cluster.
STORER_ERROR_COUNT - Static variable in class org.apache.pig.CounterBasedErrorHandler
 
STORER_ERROR_HANDLER_COUNTER_GROUP - Static variable in class org.apache.pig.CounterBasedErrorHandler
 
STORER_RECORD_COUNT - Static variable in class org.apache.pig.CounterBasedErrorHandler
 
StoreResources - Interface in org.apache.pig
This interface allow StoreFunc to specify resources needed in distributed cache.
stores - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
 
stores - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapReduce.Reduce
 
storeSchema(ResourceSchema, String, Job) - Method in class org.apache.pig.builtin.JsonMetadata
 
storeSchema(ResourceSchema, String, Job) - Method in class org.apache.pig.builtin.JsonStorage
 
storeSchema(ResourceSchema, String, Job) - Method in class org.apache.pig.builtin.mock.Storage
 
storeSchema(ResourceSchema, String, Job) - Method in class org.apache.pig.builtin.PigStorage
 
storeSchema(ResourceSchema, String, Job) - Method in class org.apache.pig.piggybank.storage.AllLoader
 
storeSchema(ResourceSchema, String, Job) - Method in class org.apache.pig.StoreFuncMetadataWrapper
 
storeSchema(ResourceSchema, String, Job) - Method in interface org.apache.pig.StoreMetadata
Store schema of the data being written
storeStatistics(ResourceStatistics, String, Job) - Method in class org.apache.pig.builtin.JsonMetadata
 
storeStatistics(ResourceStatistics, String, Job) - Method in class org.apache.pig.builtin.JsonStorage
 
storeStatistics(ResourceStatistics, String, Job) - Method in class org.apache.pig.builtin.mock.Storage
 
storeStatistics(ResourceStatistics, String, Job) - Method in class org.apache.pig.builtin.PigStorage
 
storeStatistics(ResourceStatistics, String, Job) - Method in class org.apache.pig.piggybank.storage.AllLoader
 
storeStatistics(ResourceStatistics, String, Job) - Method in class org.apache.pig.piggybank.storage.FixedWidthStorer
 
storeStatistics(ResourceStatistics, String, Job) - Method in class org.apache.pig.StoreFuncMetadataWrapper
 
storeStatistics(ResourceStatistics, String, Job) - Method in interface org.apache.pig.StoreMetadata
Store statistics about the data being written.
StreamConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
StreamConverter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.StreamConverter
 
StreamGenerator - Class in org.apache.pig.tools.streams
 
StreamGenerator() - Constructor for class org.apache.pig.tools.streams.StreamGenerator
 
StreamingCommand - Class in org.apache.pig.impl.streaming
StreamingCommand represents the specification of an external command to be executed in a Pig Query.
StreamingCommand(PigContext, String[]) - Constructor for class org.apache.pig.impl.streaming.StreamingCommand
Create a new StreamingCommand with the given command.
StreamingCommand.Handle - Enum in org.apache.pig.impl.streaming
Handle to communicate with the external process.
StreamingCommand.HandleSpec - Class in org.apache.pig.impl.streaming
Specification about the usage of the StreamingCommand.Handle to communicate with the external process.
StreamingCommandUtils - Class in org.apache.pig.parser
 
StreamingCommandUtils(PigContext) - Constructor for class org.apache.pig.parser.StreamingCommandUtils
 
StreamingDelimiters - Class in org.apache.pig.impl.streaming
 
StreamingDelimiters() - Constructor for class org.apache.pig.impl.streaming.StreamingDelimiters
 
StreamingDelimiters(byte, byte, boolean) - Constructor for class org.apache.pig.impl.streaming.StreamingDelimiters
 
StreamingUDF - Class in org.apache.pig.impl.builtin
 
StreamingUDF(String, String, String, String, String, String, String) - Constructor for class org.apache.pig.impl.builtin.StreamingUDF
 
StreamingUDF.ProcessKiller - Class in org.apache.pig.impl.builtin
 
StreamingUDFException - Exception in org.apache.pig.impl.streaming
 
StreamingUDFException() - Constructor for exception org.apache.pig.impl.streaming.StreamingUDFException
 
StreamingUDFException(String) - Constructor for exception org.apache.pig.impl.streaming.StreamingUDFException
 
StreamingUDFException(String, Integer) - Constructor for exception org.apache.pig.impl.streaming.StreamingUDFException
 
StreamingUDFException(String, String, Throwable) - Constructor for exception org.apache.pig.impl.streaming.StreamingUDFException
 
StreamingUDFException(String, String) - Constructor for exception org.apache.pig.impl.streaming.StreamingUDFException
 
StreamingUDFException(String, String, Integer) - Constructor for exception org.apache.pig.impl.streaming.StreamingUDFException
 
StreamingUDFInputHandler - Class in org.apache.pig.impl.streaming
 
StreamingUDFInputHandler(PigStreamingBase) - Constructor for class org.apache.pig.impl.streaming.StreamingUDFInputHandler
 
StreamingUDFOutputHandler - Class in org.apache.pig.impl.streaming
 
StreamingUDFOutputHandler(PigStreamingUDF) - Constructor for class org.apache.pig.impl.streaming.StreamingUDFOutputHandler
 
StreamingUDFOutputSchemaException - Exception in org.apache.pig.impl.streaming
 
StreamingUDFOutputSchemaException(String, int) - Constructor for exception org.apache.pig.impl.streaming.StreamingUDFOutputSchemaException
 
StreamingUtil - Class in org.apache.pig.impl.streaming
 
StreamingUtil() - Constructor for class org.apache.pig.impl.streaming.StreamingUtil
 
StreamPrinter(InputStream, String, PrintStream) - Constructor for class org.apache.pig.tools.grunt.GruntParser.StreamPrinter
 
StreamToPig - Interface in org.apache.pig
Deprecated.
StreamTypeCastInserter - Class in org.apache.pig.newplan.logical.rules
 
StreamTypeCastInserter(String) - Constructor for class org.apache.pig.newplan.logical.rules.StreamTypeCastInserter
 
StringConcat - Class in org.apache.pig.builtin
This method should never be used directly, use CONCAT.
StringConcat() - Constructor for class org.apache.pig.builtin.StringConcat
 
stringifySchema(StringBuilder, Schema, byte) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
stringifySchema(StringBuilder, Schema, byte, int) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
StringMax - Class in org.apache.pig.builtin
This method should never be used directly, use MAX.
StringMax() - Constructor for class org.apache.pig.builtin.StringMax
 
StringMax.Final - Class in org.apache.pig.builtin
 
StringMax.Initial - Class in org.apache.pig.builtin
 
StringMax.Intermediate - Class in org.apache.pig.builtin
 
StringMin - Class in org.apache.pig.builtin
This method should never be used directly, use MIN.
StringMin() - Constructor for class org.apache.pig.builtin.StringMin
 
StringMin.Final - Class in org.apache.pig.builtin
 
StringMin.Initial - Class in org.apache.pig.builtin
 
StringMin.Intermediate - Class in org.apache.pig.builtin
 
StringSchema - Static variable in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
 
StringSize - Class in org.apache.pig.builtin
This method should never be used directly, use SIZE.
StringSize() - Constructor for class org.apache.pig.builtin.StringSize
 
stringToBoolean(String) - Static method in class org.apache.pig.impl.util.CastUtils
 
stringToDouble(String) - Static method in class org.apache.pig.impl.util.CastUtils
 
stringToFloat(String) - Static method in class org.apache.pig.impl.util.CastUtils
 
stringToInteger(String) - Static method in class org.apache.pig.impl.util.CastUtils
 
stringToLong(String) - Static method in class org.apache.pig.impl.util.CastUtils
 
StringUtils - Class in org.apache.pig.impl.util
 
StringUtils() - Constructor for class org.apache.pig.impl.util.StringUtils
 
STRSPLIT - Class in org.apache.pig.builtin
Wrapper around Java's String.split
input tuple: first column is assumed to have a string to split;
the optional second column is assumed to have the delimiter or regex to split on;
if not provided, it's assumed to be '\s' (space)
the optional third column may provide a limit to the number of results.
If limit is not provided, 0 is assumed, as per Java's split().
STRSPLIT() - Constructor for class org.apache.pig.builtin.STRSPLIT
 
STRSPLITTOBAG - Class in org.apache.pig.builtin
Wrapper around Java's String.split
input tuple: first column is assumed to have a string to split;
the optional second column is assumed to have the delimiter or regex to split on;
if not provided, it's assumed to be '\s' (space)
the optional third column may provide a limit to the number of results.
If limit is not provided, 0 is assumed, as per Java's split().
STRSPLITTOBAG() - Constructor for class org.apache.pig.builtin.STRSPLITTOBAG
 
StructuresHelper - Class in org.apache.pig.data.utils
 
StructuresHelper.Pair<T1,T2> - Class in org.apache.pig.data.utils
This is a helper class which makes it easy to have pairs of values, and to use them as keys and values in Maps.
StructuresHelper.SchemaKey - Class in org.apache.pig.data.utils
This encapsulates a Schema and allows it to be used in such a way that any aliases are ignored in equality.
StructuresHelper.Triple<T1,T2,T3> - Class in org.apache.pig.data.utils
 
Stuff - Class in org.apache.pig.piggybank.evaluation.string
Given a string, this UDF replaces a substring given its starting index and length with the given replacement string.
Stuff() - Constructor for class org.apache.pig.piggybank.evaluation.string.Stuff
 
STYLE_UNIX - Static variable in class org.apache.pig.impl.io.FileLocalizer
 
STYLE_WINDOWS - Static variable in class org.apache.pig.impl.io.FileLocalizer
 
subPlan - Variable in class org.apache.pig.newplan.logical.rules.PartitionFilterOptimizer.PartitionFilterPushDownTransformer
 
substitute(String) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
 
substitute(String, String) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
 
substituteVars(String) - Static method in class org.apache.pig.impl.util.Utils
 
SUBSTRING - Class in org.apache.pig.builtin
SUBSTRING implements eval function to get a part of a string.
SUBSTRING() - Constructor for class org.apache.pig.builtin.SUBSTRING
 
SUBSTRING - Class in org.apache.pig.piggybank.evaluation.string
Deprecated.
SUBSTRING() - Constructor for class org.apache.pig.piggybank.evaluation.string.SUBSTRING
Deprecated.
 
Subtract - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
Subtract(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
Subtract(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
subtract(Number, Number, byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
SUBTRACT - Class in org.apache.pig.builtin
SUBTRACT takes two bags as arguments and returns a new bag composed of tuples of first bag not in the second bag.
If null, bag arguments are replaced by empty bags.
SUBTRACT() - Constructor for class org.apache.pig.builtin.SUBTRACT
 
SubtractDuration - Class in org.apache.pig.builtin
SubtractDuration returns the result of a DateTime object plus a Duration object
SubtractDuration() - Constructor for class org.apache.pig.builtin.SubtractDuration
 
SubtractExpression - Class in org.apache.pig.newplan.logical.expression
Subtract Operator
SubtractExpression(OperatorPlan, LogicalExpression, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.SubtractExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
SubtreeDependencyOrderWalker - Class in org.apache.pig.newplan
 
SubtreeDependencyOrderWalker(OperatorPlan) - Constructor for class org.apache.pig.newplan.SubtreeDependencyOrderWalker
 
SubtreeDependencyOrderWalker(OperatorPlan, Operator) - Constructor for class org.apache.pig.newplan.SubtreeDependencyOrderWalker
 
SUCCEEDED_FILE_NAME - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceLauncher
 
SUCCESS - Static variable in class org.apache.pig.PigRunner.ReturnCode
 
SUCCESS_HEADER - Static variable in class org.apache.pig.tools.pigstats.JobStats
 
SUCCESS_HEADER - Static variable in class org.apache.pig.tools.pigstats.mapreduce.MRJobStats
 
SUCCESS_HEADER - Static variable in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
sum(Tuple) - Static method in class org.apache.pig.builtin.AVG
 
sum(Tuple) - Static method in class org.apache.pig.builtin.BigDecimalAvg
 
sum(Tuple) - Static method in class org.apache.pig.builtin.BigIntegerAvg
 
sum(Tuple) - Static method in class org.apache.pig.builtin.COUNT
 
sum(Tuple) - Static method in class org.apache.pig.builtin.COUNT_STAR
 
sum(Tuple) - Static method in class org.apache.pig.builtin.DoubleAvg
 
sum(Tuple) - Static method in class org.apache.pig.builtin.FloatAvg
 
sum(Tuple) - Static method in class org.apache.pig.builtin.IntAvg
 
sum(Tuple) - Static method in class org.apache.pig.builtin.LongAvg
 
SUM - Class in org.apache.pig.builtin
Generates the sum of a set of values.
SUM() - Constructor for class org.apache.pig.builtin.SUM
 
SUM.Final - Class in org.apache.pig.builtin
 
SUM.Intermediate - Class in org.apache.pig.builtin
 
SUMIT_REPLICATION - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
supports(POStore, Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.FileBasedOutputSizeReader
Returns whether the given POStore is supported by this output size reader or not.
supports(POStore, Configuration) - Method in interface org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigStatsOutputSizeReader
Returns whether the given PSStore is supported by this output size reader or not.
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter.InnerOperator
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryExpressionOperator
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POBroadcastSpark
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PONative
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POReservoirSample
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POJoinGroupSpark
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POSampleSortSpark
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter.InnerOperator
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffledValueInputTez
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffleTezLoad
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueInputTez
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerNode
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.plan.Operator
Indicates whether this operator supports multiple inputs.
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter.InnerOperator
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POBroadcastSpark
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PONative
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POReservoirSample
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POJoinGroupSpark
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POSampleSortSpark
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter.InnerOperator
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffledValueInputTez
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueInputTez
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerNode
 
supportsMultipleOutputs() - Method in class org.apache.pig.impl.plan.Operator
Indicates whether this operator supports multiple outputs.
supportsParallelWriteToStoreLocation() - Method in class org.apache.pig.piggybank.storage.DBStorage
 
supportsParallelWriteToStoreLocation() - Method in class org.apache.pig.piggybank.storage.MultiStorage
 
supportsParallelWriteToStoreLocation() - Method in class org.apache.pig.StoreFunc
DAG execution engines like Tez support optimizing union by writing to output location in parallel from tasks of different vertices.
swap(E, E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Swap two operators in a plan.
SYNC_INTERVAL_KEY - Static variable in class org.apache.pig.piggybank.storage.avro.PigAvroOutputFormat
The configuration key for Avro sync interval.
synthetic - Variable in class org.apache.pig.pen.util.ExampleTuple
 
systemElement() - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
Defines whether the element is visible to users or contains system's metadata
systemElement() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 

T

table - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
tableName - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
TableSplitComparable - Class in org.apache.pig.backend.hadoop.hbase
 
TableSplitComparable() - Constructor for class org.apache.pig.backend.hadoop.hbase.TableSplitComparable
 
TableSplitComparable(TableSplit) - Constructor for class org.apache.pig.backend.hadoop.hbase.TableSplitComparable
 
tabs - Variable in class org.apache.pig.newplan.logical.optimizer.LogicalPlanPrinter
 
TAN - Class in org.apache.pig.builtin
TAN implements a binding to the Java function Math.tan(double).
TAN() - Constructor for class org.apache.pig.builtin.TAN
 
TAN - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use TAN
TAN() - Constructor for class org.apache.pig.piggybank.evaluation.math.TAN
Deprecated.
 
TANH - Class in org.apache.pig.builtin
TANH implements a binding to the Java function Math.tanh(double).
TANH() - Constructor for class org.apache.pig.builtin.TANH
 
TANH - Class in org.apache.pig.piggybank.evaluation.math
Deprecated.
Use TANH
TANH() - Constructor for class org.apache.pig.piggybank.evaluation.math.TANH
Deprecated.
 
TargetedTuple - Class in org.apache.pig.data
A tuple composed with the operators to which it needs be attached
TargetedTuple() - Constructor for class org.apache.pig.data.TargetedTuple
 
TargetedTuple(Tuple, List<OperatorKey>) - Constructor for class org.apache.pig.data.TargetedTuple
 
targetOps - Variable in class org.apache.pig.data.TargetedTuple
 
TASK_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
 
TASK_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.PigStatsUtil
Deprecated.
TASK_COUNTER_GROUP - Static variable in class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
TASK_ID - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
TASK_INDEX - Static variable in class org.apache.pig.PigConstants
 
TASK_IS_MAP - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
TASK_PARTITION - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
TASK_TIMEOUT - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
TaskContext<T> - Class in org.apache.pig.backend.hadoop.executionengine
 
TaskContext() - Constructor for class org.apache.pig.backend.hadoop.executionengine.TaskContext
 
taskID - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter.PigMapCounter
 
taskID - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduceCounter.PigReduceCounter
 
tearDown() - Method in class org.apache.pig.backend.hadoop.executionengine.fetch.FetchPOStoreImpl
 
tearDown() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReducePOStoreImpl
 
tearDown() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
At the end of processing, the inputstream is closed using this method
tearDown() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
Called at the end of processing for clean up.
tearDown() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStoreImpl
At the end of processing, the outputstream is closed using this method
tell() - Method in class org.apache.pig.backend.datastorage.SeekableInputStream
Returns current offset
tell() - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
tell() - Method in class org.apache.pig.piggybank.storage.avro.AvroStorageInputStream
 
terminate() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.MonitoredUDFExecutor
This method *MUST* be called in the finish by POUserFunc.
TerminatingAccumulator<T> - Interface in org.apache.pig
This is an interface which, if implemented, allows an Accumulator function to signal that it can terminate early.
TextLoader - Class in org.apache.pig.builtin
This load function simply creates a tuple for each line of text that has a single chararray field that contains the line of text.
TextLoader() - Constructor for class org.apache.pig.builtin.TextLoader
 
TEXTOUTPUTFORMAT_SEPARATOR - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
textToTuple(Text, byte) - Static method in class org.apache.pig.impl.util.StorageUtil
Transform a line of Text to a Tuple
TezCompiler - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
The compiler that compiles a given physical plan into a DAG of Tez operators which can then be converted into the JobControl structure.
TezCompiler(PhysicalPlan, PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
TezCompilerException - Exception in org.apache.pig.backend.hadoop.executionengine.tez.plan
 
TezCompilerException() - Constructor for exception org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompilerException
Create a new TezCompilerException with null as the error message.
TezCompilerException(String) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompilerException
Create a new TezCompilerException with the specified message and cause.
TezCompilerException(Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompilerException
Create a new TezCompilerException with the specified cause.
TezCompilerException(String, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompilerException
Create a new TezCompilerException with the specified message and cause.
TezCompilerException(String, int) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompilerException
Create a new TezCompilerException with the specified message and cause.
TezCompilerException(String, int, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompilerException
Create a new TezCompilerException with the specified message and cause.
TezCompilerException(String, int, byte) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompilerException
Create a new TezCompilerException with the specified message and cause.
TezCompilerException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompilerException
Create a new TezCompilerException with the specified message and cause.
TezCompilerException(String, int, boolean) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompilerException
Create a new TezCompilerException with the specified message and cause.
TezCompilerException(String, int, byte, boolean) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompilerException
Create a new TezCompilerException with the specified message and cause.
TezCompilerException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompilerException
Create a new TezCompilerException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
TezCompilerException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompilerException
Create a new TezCompilerException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
TezCompilerUtil - Class in org.apache.pig.backend.hadoop.executionengine.tez.util
 
TezDagBuilder - Class in org.apache.pig.backend.hadoop.executionengine.tez
A visitor to construct DAG out of Tez plan.
TezDagBuilder(PigContext, TezOperPlan, DAG, Map<String, LocalResource>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.TezDagBuilder
 
TezDAGGraphPrinter(TezPlanContainer) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPrinter.TezDAGGraphPrinter
 
TezDAGScriptInfo(TezOperPlan) - Constructor for class org.apache.pig.tools.pigstats.tez.TezScriptState.TezDAGScriptInfo
 
TezDAGStats - Class in org.apache.pig.tools.pigstats.tez
 
TezDAGStats(String, PigStats.JobGraph, Map<String, TezVertexStats>, StringBuilder) - Constructor for class org.apache.pig.tools.pigstats.tez.TezDAGStats
 
TezEdgeDescriptor - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
Descriptor for Tez edge.
TezEdgeDescriptor() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezEdgeDescriptor
 
TezEstimatedParallelismClearer - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
 
TezEstimatedParallelismClearer(TezOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezEstimatedParallelismClearer
 
TezExecType - Class in org.apache.pig.backend.hadoop.executionengine.tez
TezExecType is the ExecType for distributed mode in Tez.
TezExecType() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.TezExecType
 
TezExecutionEngine - Class in org.apache.pig.backend.hadoop.executionengine.tez
 
TezExecutionEngine(PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.TezExecutionEngine
 
TezInput - Interface in org.apache.pig.backend.hadoop.executionengine.tez.runtime
This interface is implemented by PhysicalOperators that can have Tez inputs attached directly to the operator.
TezJob - Class in org.apache.pig.backend.hadoop.executionengine.tez
Wrapper class that encapsulates Tez DAG.
TezJob(TezConfiguration, DAG, Map<String, LocalResource>, TezOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.TezJob
 
TezJobCompiler - Class in org.apache.pig.backend.hadoop.executionengine.tez
This is compiler class that takes a TezOperPlan and converts it into a JobControl object with the relevant dependency info maintained.
TezJobCompiler(PigContext, Configuration) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.TezJobCompiler
 
TezLauncher - Class in org.apache.pig.backend.hadoop.executionengine.tez
Main class that launches pig for Tez
TezLauncher() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.TezLauncher
 
TezLocalExecType - Class in org.apache.pig.backend.hadoop.executionengine.tez
TezExecType is the ExecType for distributed mode in Tez.
TezLocalExecType() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.TezLocalExecType
 
TezOperator - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
An operator model for a Tez job.
TezOperator(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
TezOperator.LoaderInfo - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
 
TezOperator.OPER_FEATURE - Enum in org.apache.pig.backend.hadoop.executionengine.tez.plan
 
TezOperator.VertexGroupInfo - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
 
TezOperDependencyParallelismEstimator - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
Estimate the parallelism of the vertex using: 1.
TezOperDependencyParallelismEstimator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezOperDependencyParallelismEstimator
 
TezOperDependencyParallelismEstimator.TezParallelismFactorVisitor - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
 
TezOperPlan - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
A Plan used to create the plan of Tez operators which can be converted into the Job Control object.
TezOperPlan() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperPlan
 
TezOpPlanVisitor - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
A visitor for the TezOperPlan class
TezOpPlanVisitor(TezOperPlan, PlanWalker<TezOperator, TezOperPlan>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOpPlanVisitor
 
TezOutput - Interface in org.apache.pig.backend.hadoop.executionengine.tez.runtime
This interface is implemented by PhysicalOperators that can have Tez outputs attached directly to the operator.
TezParallelismEstimator - Interface in org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
 
TezParallelismFactorVisitor(TezOperator, TezOperator) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezOperDependencyParallelismEstimator.TezParallelismFactorVisitor
 
TezPigScriptStats - Class in org.apache.pig.tools.pigstats.tez
 
TezPigScriptStats(PigContext) - Constructor for class org.apache.pig.tools.pigstats.tez.TezPigScriptStats
 
TezPlanContainer - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
 
TezPlanContainer(PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainer
 
TezPlanContainerNode - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
 
TezPlanContainerNode(OperatorKey, TezOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerNode
 
TezPlanContainerPrinter - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
 
TezPlanContainerPrinter(PrintStream, TezPlanContainer) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerPrinter
 
TezPlanContainerUDFCollector - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
 
TezPlanContainerUDFCollector(TezPlanContainer) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerUDFCollector
 
TezPlanContainerVisitor - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
 
TezPlanContainerVisitor(TezPlanContainer, PlanWalker<TezPlanContainerNode, TezPlanContainer>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerVisitor
 
TezPOPackageAnnotator - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
A port of the POPackageAnnotator from MR to Tez.
TezPOPackageAnnotator(TezOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOPackageAnnotator
 
TezPOPackageAnnotator.LoRearrangeDiscoverer - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
Physical Plan visitor which tries to get the LocalRearrange(s) present in the plan (if any) and annotate the POPackage given to it with the information in the LocalRearrange (regarding columns in the "value" present in the "key")
TezPOStreamVisitor - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
 
TezPOStreamVisitor(TezOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOStreamVisitor
 
TezPOUserFuncVisitor - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
 
TezPOUserFuncVisitor(TezOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOUserFuncVisitor
 
TezPrinter - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
A visitor to print out the Tez plan.
TezPrinter(PrintStream, TezOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPrinter
 
TezPrinter.TezDAGGraphPrinter - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
This class prints the Tez DAG Graph
TezPrinter.TezVertexGraphPrinter - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan
This class prints the Tez Vertex Graph
TezResourceManager - Class in org.apache.pig.backend.hadoop.executionengine.tez
 
TezResourceManager() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.TezResourceManager
 
TezRuntimeUtil - Class in org.apache.pig.backend.hadoop.executionengine.tez.util
 
TezRuntimeUtil() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.util.TezRuntimeUtil
 
TezScriptState - Class in org.apache.pig.tools.pigstats.tez
ScriptStates encapsulates settings for a Pig script that runs on a hadoop cluster.
TezScriptState(String) - Constructor for class org.apache.pig.tools.pigstats.tez.TezScriptState
 
TezScriptState.TezDAGScriptInfo - Class in org.apache.pig.tools.pigstats.tez
 
TezSessionManager - Class in org.apache.pig.backend.hadoop.executionengine.tez
 
TezTaskConfigurable - Interface in org.apache.pig.backend.hadoop.executionengine.tez.runtime
This interface is implemented by PhysicalOperators that can need to access TezProcessorContext of a Tez task.
TezTaskContext - Class in org.apache.pig.backend.hadoop.executionengine.tez.runtime
 
TezTaskContext(ProcessorContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.runtime.TezTaskContext
 
TezUDFContextSeparator - Class in org.apache.pig.backend.hadoop.executionengine.tez.util
 
TezUDFContextSeparator(TezOperPlan, PlanWalker<TezOperator, TezOperPlan>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.util.TezUDFContextSeparator
 
TezVertexGraphPrinter(TezOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPrinter.TezVertexGraphPrinter
 
TezVertexStats - Class in org.apache.pig.tools.pigstats.tez
 
TezVertexStats(String, PigStats.JobGraph, boolean) - Constructor for class org.apache.pig.tools.pigstats.tez.TezVertexStats
 
tf - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SkewedPartitioner
 
tf - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigGenericMapBase
 
tf - Static variable in class org.apache.pig.impl.builtin.IsFirstReduceOfKey
 
TFileInputFormat() - Constructor for class org.apache.pig.impl.io.TFileStorage.TFileInputFormat
 
TFileOutputFormat() - Constructor for class org.apache.pig.impl.io.TFileStorage.TFileOutputFormat
 
TFileRecordReader - Class in org.apache.pig.impl.io
A record reader used to read data written using InterRecordWriter It uses the default InterSedes object for deserialization.
TFileRecordReader() - Constructor for class org.apache.pig.impl.io.TFileRecordReader
 
TFileRecordWriter - Class in org.apache.pig.impl.io
A record reader used to write data compatible with InterRecordWriter It uses the default InterSedes object for serialization.
TFileRecordWriter(Path, String, Configuration) - Constructor for class org.apache.pig.impl.io.TFileRecordWriter
 
TFileStorage - Class in org.apache.pig.impl.io
LOAD FUNCTION FOR PIG INTERNAL USE ONLY! This load function is used for storing intermediate data between MR jobs of a pig query.
TFileStorage() - Constructor for class org.apache.pig.impl.io.TFileStorage
Simple binary nested reader format
TFileStorage.TFileInputFormat - Class in org.apache.pig.impl.io
 
TFileStorage.TFileOutputFormat - Class in org.apache.pig.impl.io
 
THROWABLE_EXCEPTION - Static variable in class org.apache.pig.PigRunner.ReturnCode
 
throwInvalidSchemaException() - Static method in class org.apache.pig.ResourceSchema.ResourceFieldSchema
 
throwProcessingException(boolean, Exception) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
TIME_UDFS_ELAPSED_TIME_COUNTER - Static variable in class org.apache.pig.PigConstants
 
TIME_UDFS_INVOCATION_COUNTER - Static variable in class org.apache.pig.PigConstants
Counter names used by pig.udf.profile
timestamp - Variable in class org.apache.pig.data.TimestampedTuple
 
TimestampedTuple - Class in org.apache.pig.data
 
TimestampedTuple(int) - Constructor for class org.apache.pig.data.TimestampedTuple
 
TimestampedTuple(String, String, int, SimpleDateFormat) - Constructor for class org.apache.pig.data.TimestampedTuple
 
timeToSleep - Variable in class org.apache.pig.backend.hadoop.PigJobControl
 
tIn - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
TINYBAG - Static variable in class org.apache.pig.data.BinInterSedes
 
TINYBYTEARRAY - Static variable in class org.apache.pig.data.BinInterSedes
 
TINYMAP - Static variable in class org.apache.pig.data.BinInterSedes
 
TINYTUPLE - Static variable in class org.apache.pig.data.BinInterSedes
 
toArray() - Method in class org.apache.pig.impl.util.IdentityHashSet
 
toArray(T[]) - Method in class org.apache.pig.impl.util.IdentityHashSet
 
TOBAG - Class in org.apache.pig.builtin
This class takes a list of items and puts them into a bag T = foreach U generate TOBAG($0, $1, $2); It's like saying this: T = foreach U generate {($0), ($1), ($2)} All arguments that are not of tuple type are inserted into a tuple before being added to the bag.
TOBAG() - Constructor for class org.apache.pig.builtin.TOBAG
 
toBag(Object) - Static method in class org.apache.pig.data.DataType
If this object is a bag, return it as a bag.
ToBag - Class in org.apache.pig.piggybank.evaluation.util
Deprecated.
Use TOBAG
ToBag() - Constructor for class org.apache.pig.piggybank.evaluation.util.ToBag
Deprecated.
 
toBigDecimal(Object) - Static method in class org.apache.pig.data.DataType
 
toBigDecimal(Object, byte) - Static method in class org.apache.pig.data.DataType
 
toBigInteger(Object) - Static method in class org.apache.pig.data.DataType
 
toBigInteger(Object, byte) - Static method in class org.apache.pig.data.DataType
 
toBoolean(Object, byte) - Static method in class org.apache.pig.data.DataType
Force a data object to a Boolean, if possible.
toBoolean(Object) - Static method in class org.apache.pig.data.DataType
 
toBytes(BigDecimal) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
Not implemented!
toBytes(BigInteger) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
toBytes(Boolean) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
toBytes(DataBag) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
NOT IMPLEMENTED
toBytes(DataByteArray) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
toBytes(DateTime) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
toBytes(Double) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
toBytes(Float) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
toBytes(Integer) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
toBytes(Long) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
toBytes(Map<String, Object>) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
NOT IMPLEMENTED
toBytes(String) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
 
toBytes(Tuple) - Method in class org.apache.pig.backend.hadoop.accumulo.AccumuloBinaryConverter
NOT IMPLEMENTED
toBytes(DataBag) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
NOT IMPLEMENTED
toBytes(String) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
toBytes(Double) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
toBytes(Float) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
toBytes(Integer) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
toBytes(Long) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
toBytes(Boolean) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
toBytes(DateTime) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
NOT IMPLEMENTED
toBytes(Map<String, Object>) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
NOT IMPLEMENTED
toBytes(Tuple) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
NOT IMPLEMENTED
toBytes(DataByteArray) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
 
toBytes(BigInteger) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
Not implemented!
toBytes(BigDecimal) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseBinaryConverter
Not implemented!
toBytes(DataBag) - Method in class org.apache.pig.builtin.BinStorage
 
toBytes(String) - Method in class org.apache.pig.builtin.BinStorage
 
toBytes(Double) - Method in class org.apache.pig.builtin.BinStorage
 
toBytes(Float) - Method in class org.apache.pig.builtin.BinStorage
 
toBytes(Integer) - Method in class org.apache.pig.builtin.BinStorage
 
toBytes(Long) - Method in class org.apache.pig.builtin.BinStorage
 
toBytes(Boolean) - Method in class org.apache.pig.builtin.BinStorage
 
toBytes(DateTime) - Method in class org.apache.pig.builtin.BinStorage
 
toBytes(Map<String, Object>) - Method in class org.apache.pig.builtin.BinStorage
 
toBytes(Tuple) - Method in class org.apache.pig.builtin.BinStorage
 
toBytes(DataBag) - Method in class org.apache.pig.builtin.TextLoader
 
toBytes(String) - Method in class org.apache.pig.builtin.TextLoader
 
toBytes(Double) - Method in class org.apache.pig.builtin.TextLoader
 
toBytes(Float) - Method in class org.apache.pig.builtin.TextLoader
 
toBytes(Boolean) - Method in class org.apache.pig.builtin.TextLoader
 
toBytes(Integer) - Method in class org.apache.pig.builtin.TextLoader
 
toBytes(Long) - Method in class org.apache.pig.builtin.TextLoader
 
toBytes(DateTime) - Method in class org.apache.pig.builtin.TextLoader
 
toBytes(Map<String, Object>) - Method in class org.apache.pig.builtin.TextLoader
 
toBytes(Tuple) - Method in class org.apache.pig.builtin.TextLoader
 
toBytes(DataBag) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(String) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(Double) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(Float) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(Integer) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(Long) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(Boolean) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(DateTime) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(Map<String, Object>) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(Tuple) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(DataByteArray) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(BigInteger) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(BigDecimal) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(Object) - Static method in class org.apache.pig.data.DataType
 
toBytes(Object, byte) - Static method in class org.apache.pig.data.DataType
 
toBytes(DataBag) - Method in interface org.apache.pig.StoreCaster
 
toBytes(String) - Method in interface org.apache.pig.StoreCaster
 
toBytes(Double) - Method in interface org.apache.pig.StoreCaster
 
toBytes(Float) - Method in interface org.apache.pig.StoreCaster
 
toBytes(Integer) - Method in interface org.apache.pig.StoreCaster
 
toBytes(Boolean) - Method in interface org.apache.pig.StoreCaster
 
toBytes(Long) - Method in interface org.apache.pig.StoreCaster
 
toBytes(DateTime) - Method in interface org.apache.pig.StoreCaster
 
toBytes(Map<String, Object>) - Method in interface org.apache.pig.StoreCaster
 
toBytes(Tuple) - Method in interface org.apache.pig.StoreCaster
 
toBytes(DataByteArray) - Method in interface org.apache.pig.StoreCaster
 
toBytes(BigInteger) - Method in interface org.apache.pig.StoreCaster
 
toBytes(BigDecimal) - Method in interface org.apache.pig.StoreCaster
 
toConfiguration(Properties) - Static method in class org.apache.pig.backend.hadoop.datastorage.ConfigurationUtil
 
toConfiguration(Properties, boolean) - Static method in class org.apache.pig.backend.hadoop.datastorage.ConfigurationUtil
 
ToDate - Class in org.apache.pig.builtin
ToDate converts the ISO or the customized string or the Unix timestamp to the DateTime object.
ToDate() - Constructor for class org.apache.pig.builtin.ToDate
 
ToDate2ARGS - Class in org.apache.pig.builtin
This method should never be used directly, use ToDate.
ToDate2ARGS() - Constructor for class org.apache.pig.builtin.ToDate2ARGS
 
ToDate3ARGS - Class in org.apache.pig.builtin
This method should never be used directly, use ToDate.
ToDate3ARGS() - Constructor for class org.apache.pig.builtin.ToDate3ARGS
 
ToDateISO - Class in org.apache.pig.builtin
This method should never be used directly, use ToDate.
ToDateISO() - Constructor for class org.apache.pig.builtin.ToDateISO
 
toDateTime(Object, byte) - Static method in class org.apache.pig.data.DataType
Force a data object to a DateTime, if possible.
toDateTime(Object) - Static method in class org.apache.pig.data.DataType
 
toDegrees - Class in org.apache.pig.piggybank.evaluation.math
math.toDegrees implements a binding to the Java function Math.toDegrees(double).
toDegrees() - Constructor for class org.apache.pig.piggybank.evaluation.math.toDegrees
 
toDelimitedString(String) - Method in class org.apache.pig.data.AbstractTuple
Write a tuple of values into a string.
toDelimitedString(String) - Method in interface org.apache.pig.data.Tuple
Write a tuple of values into a string.
toDelimitedString(String) - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
toDouble(Object, byte) - Static method in class org.apache.pig.data.DataType
Force a data object to a Double, if possible.
toDouble(Object) - Static method in class org.apache.pig.data.DataType
Force a data object to a Double, if possible.
toEdges - Variable in class org.apache.pig.newplan.BaseOperatorPlan
 
toFloat(Object, byte) - Static method in class org.apache.pig.data.DataType
Force a data object to a Float, if possible.
toFloat(Object) - Static method in class org.apache.pig.data.DataType
Force a data object to a Float, if possible.
toInteger(Object, byte) - Static method in class org.apache.pig.data.DataType
Force a data object to an Integer, if possible.
toInteger(Object) - Static method in class org.apache.pig.data.DataType
Force a data object to an Integer, if possible.
TOKENIZE - Class in org.apache.pig.builtin
Given a chararray as an argument, this method will split the chararray and return a bag with a tuple for each chararray that results from the split.
TOKENIZE() - Constructor for class org.apache.pig.builtin.TOKENIZE
 
toLong(Object, byte) - Static method in class org.apache.pig.data.DataType
Force a data object to a Long, if possible.
toLong(Object) - Static method in class org.apache.pig.data.DataType
Force a data object to a Long, if possible.
TOMAP - Class in org.apache.pig.builtin
This class makes a map out of the parameters passed to it T = foreach U generate TOMAP($0, $1, $2, $3); It generates a map $0->1, $2->$3 This UDF also accepts a bag with 'pair' tuples (i.e.
TOMAP() - Constructor for class org.apache.pig.builtin.TOMAP
 
toMap(Object) - Static method in class org.apache.pig.data.DataType
If this object is a map, return it as a map.
ToMilliSeconds - Class in org.apache.pig.builtin
ToMilliSeconds converts the DateTime to the number of milliseconds that have passed since January 1, 1970 00:00:00.000 GMT.
ToMilliSeconds() - Constructor for class org.apache.pig.builtin.ToMilliSeconds
 
ToolsPigServer - Class in org.apache.pig.tools
ToolsPigServer is a subclass of PigServer intended only for Pig tools.
ToolsPigServer(String) - Constructor for class org.apache.pig.tools.ToolsPigServer
 
ToolsPigServer(PigContext) - Constructor for class org.apache.pig.tools.ToolsPigServer
 
ToolsPigServer(ExecType, Properties) - Constructor for class org.apache.pig.tools.ToolsPigServer
 
ToolsPigServer.PigPlans - Class in org.apache.pig.tools
 
TOP - Class in org.apache.pig.builtin
Top UDF accepts a bag of tuples and returns top-n tuples depending upon the tuple field value of type long.
TOP() - Constructor for class org.apache.pig.builtin.TOP
 
TOP(String) - Constructor for class org.apache.pig.builtin.TOP
 
Top - Class in org.apache.pig.piggybank.evaluation.util
Deprecated.
Use TOP
Top() - Constructor for class org.apache.pig.piggybank.evaluation.util.Top
Deprecated.
 
TOP.Final - Class in org.apache.pig.builtin
 
Top.Final - Class in org.apache.pig.piggybank.evaluation.util
Deprecated.
 
TOP.Initial - Class in org.apache.pig.builtin
 
Top.Initial - Class in org.apache.pig.piggybank.evaluation.util
Deprecated.
 
TOP.Intermed - Class in org.apache.pig.builtin
 
Top.Intermed - Class in org.apache.pig.piggybank.evaluation.util
Deprecated.
 
toProperties(Configuration) - Static method in class org.apache.pig.backend.hadoop.datastorage.ConfigurationUtil
 
toRadians - Class in org.apache.pig.piggybank.evaluation.math
math.toRadians implements a binding to the Java function Math.toRadians(double).
toRadians() - Constructor for class org.apache.pig.piggybank.evaluation.math.toRadians
 
toScalaSeq(List<T>) - Static method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkUtil
 
toString() - Method in class org.apache.pig.backend.hadoop.accumulo.Column
 
toString() - Method in class org.apache.pig.backend.hadoop.BigDecimalWritable
 
toString() - Method in class org.apache.pig.backend.hadoop.BigIntegerWritable
 
toString() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
toString() - Method in class org.apache.pig.backend.hadoop.DateTimeWritable
 
toString() - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnChainInfo
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ColumnInfo
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.LocalExecType
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRExecType
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.DiscreteProbabilitySampleGenerator
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.MROperPlan
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SortKeyInfo
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator.OriginalLocation
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PatternNode
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.Result
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.converter.IndexedKey
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperPlan
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkExecType
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperPlan
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainer
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerNode
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPrinter.TezDAGGraphPrinter
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPrinter.TezVertexGraphPrinter
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezExecType
 
toString() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage.ColumnInfo
 
toString() - Method in class org.apache.pig.backend.hadoop.hbase.TableSplitComparable
 
toString() - Method in class org.apache.pig.builtin.COR
Function to return argument of constructor as string.
toString() - Method in class org.apache.pig.builtin.COV
Function to return argument of constructor as string.
ToString - Class in org.apache.pig.builtin
ToString converts the DateTime object of the ISO or the customized string.
ToString() - Constructor for class org.apache.pig.builtin.ToString
 
toString() - Method in class org.apache.pig.data.AbstractTuple
 
toString() - Method in class org.apache.pig.data.DataByteArray
Convert the byte array to a string.
toString(Object, byte) - Static method in class org.apache.pig.data.DataType
Force a data object to a String, if possible.
toString(Object) - Static method in class org.apache.pig.data.DataType
Force a data object to a String, if possible.
toString() - Method in class org.apache.pig.data.DefaultAbstractBag
Write the bag into a string.
toString() - Method in class org.apache.pig.data.LimitedSortedDataBag
Write the bag into a string.
toString() - Method in class org.apache.pig.data.NonSpillableDataBag
Write the bag into a string.
toString() - Method in class org.apache.pig.data.SingleTupleBag
Write the bag into a string.
toString() - Method in class org.apache.pig.data.TargetedTuple
 
toString() - Method in class org.apache.pig.data.utils.StructuresHelper.Pair
 
toString() - Method in class org.apache.pig.data.utils.StructuresHelper.SchemaKey
 
toString() - Method in class org.apache.pig.data.utils.StructuresHelper.Triple
 
toString() - Method in class org.apache.pig.Expression.BetweenExpression
 
toString() - Method in class org.apache.pig.Expression.BinaryExpression
 
toString() - Method in class org.apache.pig.Expression.Column
 
toString() - Method in class org.apache.pig.Expression.Const
 
toString() - Method in class org.apache.pig.Expression.InExpression
 
toString() - Method in enum org.apache.pig.Expression.OpType
 
toString() - Method in class org.apache.pig.Expression.UnaryExpression
 
toString() - Method in class org.apache.pig.FileSplitComparable
 
toString() - Method in class org.apache.pig.FuncSpec
 
toString() - Method in class org.apache.pig.impl.io.FileSpec
 
toString() - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
toString() - Method in class org.apache.pig.impl.io.PigFile
 
toString() - Method in class org.apache.pig.impl.io.PigNullableWritable
 
toString() - Method in exception org.apache.pig.impl.io.ResourceNotFoundException
 
toString() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
 
toString() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
toString() - Method in enum org.apache.pig.impl.plan.CompilationMessageCollector.Unknown
 
toString() - Method in class org.apache.pig.impl.plan.MapKeysInfo
 
toString() - Method in class org.apache.pig.impl.plan.Operator
 
toString() - Method in class org.apache.pig.impl.plan.OperatorKey
 
toString() - Method in class org.apache.pig.impl.plan.ProjectionMap.Column
 
toString() - Method in class org.apache.pig.impl.plan.ProjectionMap
 
toString() - Method in class org.apache.pig.impl.plan.RequiredFields
 
toString() - Method in class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
 
toString() - Method in class org.apache.pig.impl.streaming.StreamingCommand
 
toString() - Method in exception org.apache.pig.impl.streaming.StreamingUDFException
 
toString() - Method in class org.apache.pig.impl.util.IdentityHashSet
 
toString() - Method in class org.apache.pig.impl.util.MultiMap
 
toString() - Method in class org.apache.pig.impl.util.Pair
 
toString() - Method in class org.apache.pig.LoadPushDown.RequiredField
 
toString() - Method in class org.apache.pig.LoadPushDown.RequiredFieldList
 
toString() - Method in class org.apache.pig.newplan.BaseOperatorPlan
 
toString() - Method in class org.apache.pig.newplan.logical.expression.DereferenceExpression
 
toString() - Method in class org.apache.pig.newplan.logical.expression.LogicalExpression
 
toString() - Method in class org.apache.pig.newplan.logical.expression.MapLookupExpression
 
toString() - Method in class org.apache.pig.newplan.logical.expression.ProjectExpression
 
toString() - Method in class org.apache.pig.newplan.logical.expression.ScalarExpression
 
toString() - Method in class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
toString() - Method in class org.apache.pig.newplan.logical.relational.LOGenerate
 
toString() - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalOperator
 
toString(boolean) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
toString() - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
toString(boolean) - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
 
toString() - Method in class org.apache.pig.newplan.logical.relational.LogicalSchema
 
toString() - Method in class org.apache.pig.newplan.logical.relational.LOInnerLoad
 
toString() - Method in class org.apache.pig.newplan.logical.relational.LOLoad
 
toString() - Method in exception org.apache.pig.parser.DuplicatedSchemaAliasException
 
toString() - Method in exception org.apache.pig.parser.InvalidCommandException
 
toString() - Method in exception org.apache.pig.parser.InvalidPathException
 
toString() - Method in exception org.apache.pig.parser.InvalidScalarProjectionException
 
toString() - Method in exception org.apache.pig.parser.NonProjectExpressionException
 
toString() - Method in exception org.apache.pig.parser.ParserException
 
toString() - Method in exception org.apache.pig.parser.ParserValidationException
 
toString() - Method in exception org.apache.pig.parser.PlanGenerationFailureException
 
toString() - Method in class org.apache.pig.parser.SourceLocation
 
toString() - Method in exception org.apache.pig.parser.UndefinedAliasException
 
toString() - Method in class org.apache.pig.pen.util.ExampleTuple
 
toString() - Method in exception org.apache.pig.PigException
Returns a short description of this throwable.
toString() - Method in class org.apache.pig.piggybank.evaluation.stats.COR
Deprecated.
Function to return argument of constructor as string.
toString() - Method in class org.apache.pig.piggybank.evaluation.stats.COV
Deprecated.
Function to return argument of constructor as string.
toString() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageInputFormat.IndexedStorageRecordReader
 
toString() - Method in class org.apache.pig.piggybank.storage.XMLLoader.XMLRecordReader
 
toString() - Method in class org.apache.pig.ResourceSchema.ResourceFieldSchema
 
toString() - Method in class org.apache.pig.ResourceSchema
 
toString() - Method in class org.apache.pig.ResourceStatistics.ResourceFieldStatistics
 
toString() - Method in class org.apache.pig.ResourceStatistics
 
toString(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubyDataByteArray
 
toString(ThreadContext) - Method in class org.apache.pig.scripting.jruby.RubySchema
The toString method just leverages Schema's printing.
toString() - Method in class org.apache.pig.SortColInfo
 
toString() - Method in class org.apache.pig.SortInfo
 
toString() - Method in class org.apache.pig.tools.pigstats.PigStats.JobGraph
 
toString() - Method in class org.apache.pig.tools.pigstats.PigStats.JobGraphPrinter
 
toString() - Method in enum org.apache.pig.tools.pigstats.ScriptState.PIG_PROPERTY
 
TOTAL_REDUCERS - Static variable in class org.apache.pig.impl.builtin.PartitionSkewedKeys
 
totalHadoopTimeSpent - Variable in class org.apache.pig.backend.hadoop.executionengine.Launcher
 
totalMemory - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
totalReducers - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.SkewedPartitioner
 
totalReducers_ - Variable in class org.apache.pig.impl.builtin.PartitionSkewedKeys
 
TOTUPLE - Class in org.apache.pig.builtin
This class makes a tuple out of the parameter T = foreach U generate TOTUPLE($0, $1, $2); It generates a tuple containing $0, $1, and $2
TOTUPLE() - Constructor for class org.apache.pig.builtin.TOTUPLE
 
toTuple(Object) - Static method in class org.apache.pig.data.DataType
If this object is a tuple, return it as a tuple.
toTuple() - Method in class org.apache.pig.data.TargetedTuple
 
toTuple() - Method in class org.apache.pig.pen.util.ExampleTuple
 
ToTuple - Class in org.apache.pig.piggybank.evaluation.util
Deprecated.
ToTuple() - Constructor for class org.apache.pig.piggybank.evaluation.util.ToTuple
Deprecated.
 
ToUnixTime - Class in org.apache.pig.builtin
ToUnixTime converts the DateTime to the Unix Time Long
ToUnixTime() - Constructor for class org.apache.pig.builtin.ToUnixTime
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.AddForEach.AddForEachTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.ColumnMapKeyPrune.ColumnMapKeyPruneTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.ConstantCalculator.ConstantCalculatorTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.FilterAboveForeach.FilterAboveForEachTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.GroupByConstParallelSetter.GroupAllParallelSetterTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.LimitOptimizer.OptimizeLimitTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.MergeFilter.MergeFilterTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.MergeForEach.MergeForEachTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.NestedLimitOptimizer.OptimizeNestedLimitTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.PartitionFilterOptimizer.PartitionFilterPushDownTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.PushUpFilter.PushUpFilterTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.SplitFilter.SplitFilterTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.logical.rules.TypeCastInserter.TypeCastInserterTransformer
 
transform(OperatorPlan) - Method in class org.apache.pig.newplan.optimizer.Transformer
Transform the tree
transformed(OperatorPlan, OperatorPlan) - Method in class org.apache.pig.newplan.logical.optimizer.ProjectionPatcher
 
transformed(OperatorPlan, OperatorPlan) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaPatcher
 
transformed(OperatorPlan, OperatorPlan) - Method in interface org.apache.pig.newplan.optimizer.PlanTransformListener
Notification that a plan has been transformed.
Transformer - Class in org.apache.pig.newplan.optimizer
 
Transformer() - Constructor for class org.apache.pig.newplan.optimizer.Transformer
 
translateFieldSchema(Schema.FieldSchema) - Static method in class org.apache.pig.newplan.logical.Util
 
translateFieldSchema(LogicalSchema.LogicalFieldSchema) - Static method in class org.apache.pig.newplan.logical.Util
 
translateMRSettingsForTezAM(TezConfiguration) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.MRToTezHelper
 
translateSchema(Schema) - Static method in class org.apache.pig.newplan.logical.Util
 
translateSchema(LogicalSchema) - Static method in class org.apache.pig.newplan.logical.Util
This function translates the new LogicalSchema into old Schema format required by PhysicalOperators
translateWritableToPigDataType(Writable, byte) - Method in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
TrevniStorage - Class in org.apache.pig.builtin
Pig Store/Load Function for Trevni.
TrevniStorage() - Constructor for class org.apache.pig.builtin.TrevniStorage
Create new instance of TrevniStorage with no arguments (useful for loading files without specifying parameters).
TrevniStorage(String, String) - Constructor for class org.apache.pig.builtin.TrevniStorage
Create new instance of TrevniStorage.
TRIM - Class in org.apache.pig.builtin
Returns a string, with leading and trailing whitespace omitted.
TRIM() - Constructor for class org.apache.pig.builtin.TRIM
 
Trim - Class in org.apache.pig.piggybank.evaluation.string
Deprecated.
Use TRIM
Trim() - Constructor for class org.apache.pig.piggybank.evaluation.string.Trim
Deprecated.
 
trimAbove(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Trim everything above a given operator.
trimBelow(E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Trim everything below a given operator.
trimBelow(Operator) - Method in class org.apache.pig.newplan.BaseOperatorPlan
Trim everything below a given operator.
Triple(T1, T2, T3) - Constructor for class org.apache.pig.data.utils.StructuresHelper.Triple
 
truncatedScript - Variable in class org.apache.pig.tools.pigstats.ScriptState
 
tryKerberosKeytabLogin(Configuration) - Static method in class org.apache.pig.backend.hadoop.HKerberos
 
tupIter - Variable in class org.apache.pig.data.ReadOnceBag
 
tuple(Object...) - Static method in class org.apache.pig.builtin.mock.Storage
 
TUPLE - Static variable in class org.apache.pig.data.BinInterSedes
 
TUPLE - Static variable in class org.apache.pig.data.DataType
 
Tuple - Interface in org.apache.pig.data
An ordered list of Data.
tuple(ThreadContext, IRubyObject, IRubyObject, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a ruby method which takes a name and an array of arguments and constructs a Tuple schema from them.
tuple(ThreadContext, IRubyObject, IRubyObject) - Static method in class org.apache.pig.scripting.jruby.RubySchema
This is a ruby method which takes an array of arguments and constructs a Tuple schema from them.
TUPLE_0 - Static variable in class org.apache.pig.data.BinInterSedes
 
TUPLE_1 - Static variable in class org.apache.pig.data.BinInterSedes
 
TUPLE_2 - Static variable in class org.apache.pig.data.BinInterSedes
 
TUPLE_3 - Static variable in class org.apache.pig.data.BinInterSedes
 
TUPLE_4 - Static variable in class org.apache.pig.data.BinInterSedes
 
TUPLE_5 - Static variable in class org.apache.pig.data.BinInterSedes
 
TUPLE_6 - Static variable in class org.apache.pig.data.BinInterSedes
 
TUPLE_7 - Static variable in class org.apache.pig.data.BinInterSedes
 
TUPLE_8 - Static variable in class org.apache.pig.data.BinInterSedes
 
TUPLE_9 - Static variable in class org.apache.pig.data.BinInterSedes
 
TUPLE_CLASS - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezCompilerUtil
 
TUPLE_NAME - Static variable in class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
 
tupleClass() - Method in class org.apache.pig.data.BinSedesTupleFactory
 
tupleClass() - Method in class org.apache.pig.data.SchemaTupleFactory
 
tupleClass() - Method in class org.apache.pig.data.TupleFactory
Return the actual class representing a tuple that the implementing factory will be returning.
TupleFactory - Class in org.apache.pig.data
A factory to construct tuples.
TupleFactory() - Constructor for class org.apache.pig.data.TupleFactory
 
tupleFactory - Variable in class org.apache.pig.piggybank.storage.HiveColumnarLoader
 
TupleFormat - Class in org.apache.pig.impl.util
Default implementation of format of Tuple.
TupleFormat() - Constructor for class org.apache.pig.impl.util.TupleFormat
 
TupleGroovyAlgebraicEvalFunc(String, String, String, String, String, String) - Constructor for class org.apache.pig.scripting.groovy.GroovyAlgebraicEvalFunc.TupleGroovyAlgebraicEvalFunc
 
tupleIndex - Static variable in class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
 
TupleJrubyAlgebraicEvalFunc(String, String) - Constructor for class org.apache.pig.scripting.jruby.JrubyAlgebraicEvalFunc.TupleJrubyAlgebraicEvalFunc
 
TupleMaker<A extends Tuple> - Interface in org.apache.pig.data
 
tupleOfLastBag - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
TupleRawComparator - Interface in org.apache.pig.data
This interface is intended to compare Tuples.
tupleRawComparatorClass() - Method in class org.apache.pig.data.BinSedesTupleFactory
 
tupleRawComparatorClass() - Method in class org.apache.pig.data.DefaultTupleFactory
Deprecated.
 
tupleRawComparatorClass() - Method in class org.apache.pig.data.TupleFactory
Return the actual class implementing the raw comparator for tuples that the factory will be returning.
TupleSize - Class in org.apache.pig.builtin
This method should never be used directly, use SIZE.
TupleSize() - Constructor for class org.apache.pig.builtin.TupleSize
 
TuplesToSchemaTupleList(int, TupleMaker<?>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin.TuplesToSchemaTupleList
 
tupleToBytes(Tuple, int, ResourceSchema.ResourceFieldSchema[]) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
TupleToMapKey(int, SchemaTupleFactory) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin.TupleToMapKey
 
tupleToText(Tuple, int, ResourceSchema.ResourceFieldSchema[]) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
TURN_ON_OUTPUT_CAPTURING - Static variable in class org.apache.pig.impl.builtin.StreamingUDF
 
type - Variable in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Datatype, using codes from DataType.
type - Variable in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
TypeAwareTuple - Interface in org.apache.pig.data
 
TypeCastInserter - Class in org.apache.pig.newplan.logical.rules
 
TypeCastInserter(String) - Constructor for class org.apache.pig.newplan.logical.rules.TypeCastInserter
 
TypeCastInserter.TypeCastInserterTransformer - Class in org.apache.pig.newplan.logical.rules
 
TypeCastInserterTransformer() - Constructor for class org.apache.pig.newplan.logical.rules.TypeCastInserter.TypeCastInserterTransformer
 
TypeCheckerException - Exception in org.apache.pig.impl.logicalLayer.validators
 
TypeCheckerException() - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with null as the error message.
TypeCheckerException(String) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified message and cause.
TypeCheckerException(Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified cause.
TypeCheckerException(String, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified message and cause.
TypeCheckerException(String, int) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified message and cause.
TypeCheckerException(String, int, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified message and cause.
TypeCheckerException(String, int, byte) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified message and cause.
TypeCheckerException(Operator, String, int, byte) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified message and cause.
TypeCheckerException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified message and cause.
TypeCheckerException(Operator, String, int, byte, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified message and cause.
TypeCheckerException(String, int, boolean) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified message and cause.
TypeCheckerException(String, int, byte, boolean) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified message and cause.
TypeCheckerException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
TypeCheckerException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.impl.logicalLayer.validators.TypeCheckerException
Create a new TypeCheckerException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
TypeCheckingExpVisitor - Class in org.apache.pig.newplan.logical.visitor
 
TypeCheckingExpVisitor(OperatorPlan, CompilationMessageCollector, LogicalRelationalOperator) - Constructor for class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
TypeCheckingRelVisitor - Class in org.apache.pig.newplan.logical.visitor
 
TypeCheckingRelVisitor(OperatorPlan, CompilationMessageCollector) - Constructor for class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
 
TypedOutputEvalFunc<OUT> - Class in org.apache.pig
Base class for Pig UDFs that are functions from Tuples to generic type OUT.
TypedOutputEvalFunc() - Constructor for class org.apache.pig.TypedOutputEvalFunc
 
typeMatch(LogicalSchema.LogicalFieldSchema, LogicalSchema.LogicalFieldSchema) - Static method in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
typeToClass(Class<?>) - Static method in class org.apache.pig.parser.LogicalPlanBuilder
 

U

UCFIRST - Class in org.apache.pig.builtin
upper-case the first character of a string
UCFIRST() - Constructor for class org.apache.pig.builtin.UCFIRST
 
UcFirst - Class in org.apache.pig.piggybank.evaluation.string
Deprecated.
UcFirst() - Constructor for class org.apache.pig.piggybank.evaluation.string.UcFirst
Deprecated.
 
UdfCacheShipFilesVisitor - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans
 
UdfCacheShipFilesVisitor(PhysicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.UdfCacheShipFilesVisitor
 
UDFContext - Class in org.apache.pig.impl.util
 
UDFContextSeparator - Class in org.apache.pig.impl.util
 
UDFContextSeparator() - Constructor for class org.apache.pig.impl.util.UDFContextSeparator
 
UDFContextSeparator.UDFType - Enum in org.apache.pig.impl.util
 
udfContextSignature - Variable in class org.apache.pig.builtin.AvroStorage
Context signature for this UDF instance.
UDFEndOfAllInputNeededVisitor - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
UDFEndOfAllInputNeededVisitor(PhysicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.UDFEndOfAllInputNeededVisitor
 
UDFFinder - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
 
UDFFinder() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.UDFFinder
 
UDFFinder(PhysicalPlan, PlanWalker<PhysicalOperator, PhysicalPlan>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.UDFFinder
 
UDFFinder - Class in org.apache.pig.newplan.logical.visitor
 
UDFFinder(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.UDFFinder
 
UDFFinishVisitor - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
UDFFinishVisitor(PhysicalPlan, PlanWalker<PhysicalOperator, PhysicalPlan>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.UDFFinishVisitor
 
UDFJarsFinder - Class in org.apache.pig.backend.hadoop.executionengine.spark
 
UDFJarsFinder(SparkOperPlan, PigContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.UDFJarsFinder
 
UDFs - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
UDFs - Variable in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
UDFs - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
UDFSortComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort.UDFSortComparator
 
uid - Variable in class org.apache.pig.newplan.logical.relational.LogicalSchema.LogicalFieldSchema
 
uidOnlyFieldSchema - Variable in class org.apache.pig.newplan.logical.expression.LogicalExpression
 
UidResetter - Class in org.apache.pig.newplan.logical.optimizer
 
UidResetter(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.optimizer.UidResetter
 
ULP - Class in org.apache.pig.piggybank.evaluation.math
math.ULP implements a binding to the Java function Math.ulp(double).
ULP() - Constructor for class org.apache.pig.piggybank.evaluation.math.ULP
 
UnaryComparisonOperator - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
This is a base class for all unary comparison operators.
UnaryComparisonOperator(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryComparisonOperator
 
UnaryComparisonOperator(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryComparisonOperator
 
UnaryExpression(Expression, Expression.OpType) - Constructor for class org.apache.pig.Expression.UnaryExpression
 
UnaryExpression - Class in org.apache.pig.newplan.logical.expression
Superclass for all unary expressions
UnaryExpression(String, OperatorPlan, LogicalExpression) - Constructor for class org.apache.pig.newplan.logical.expression.UnaryExpression
Will add this operator to the plan and connect it to the left and right hand side operators.
UnaryExpressionOperator - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators
 
UnaryExpressionOperator(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryExpressionOperator
 
UnaryExpressionOperator(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryExpressionOperator
 
unbox(Object, DataBag) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Object, Map<String, Object>) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Object, byte[]) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Object, int) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Object, long) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Object, float) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Object, double) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Object, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Object, DateTime) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Object, BigDecimal) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Object, BigInteger) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Object, String) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Object, Tuple) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(DataBag) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Map<String, Object>) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(DataByteArray) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Integer) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Long) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Float) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Double) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(Boolean) - Method in class org.apache.pig.data.SchemaTuple
 
unbox(DateTime) - Method in class org.apache.pig.data.SchemaTuple
 
unboxBigDecimal(Object) - Method in class org.apache.pig.data.SchemaTuple
 
unboxBigInteger(Object) - Method in class org.apache.pig.data.SchemaTuple
 
unboxBoolean(Object) - Method in class org.apache.pig.data.SchemaTuple
 
unboxBytes(Object) - Method in class org.apache.pig.data.SchemaTuple
 
unboxDataBag(Object) - Method in class org.apache.pig.data.SchemaTuple
 
unboxDateTime(Object) - Method in class org.apache.pig.data.SchemaTuple
 
unboxDouble(Object) - Method in class org.apache.pig.data.SchemaTuple
 
unboxFloat(Object) - Method in class org.apache.pig.data.SchemaTuple
 
unboxInt(Object) - Method in class org.apache.pig.data.SchemaTuple
 
unboxLong(Object) - Method in class org.apache.pig.data.SchemaTuple
 
unboxMap(Object) - Method in class org.apache.pig.data.SchemaTuple
 
unboxString(Object) - Method in class org.apache.pig.data.SchemaTuple
 
unboxTuple(Object) - Method in class org.apache.pig.data.SchemaTuple
 
uncaughtException(Thread, Throwable) - Method in class org.apache.pig.backend.hadoop.executionengine.Launcher.JobControlThreadExceptionHandler
 
UndefinedAliasException - Exception in org.apache.pig.parser
 
UndefinedAliasException(IntStream, SourceLocation, String) - Constructor for exception org.apache.pig.parser.UndefinedAliasException
 
unescapeInputString(String) - Static method in class org.apache.pig.impl.util.StringUtils
 
union(Tuple, Tuple) - Method in class org.apache.pig.impl.util.LineageTracer
 
union(Tuple, Tuple) - Method in class org.apache.pig.pen.util.LineageTracer
 
UnionConverter - Class in org.apache.pig.backend.hadoop.executionengine.spark.converter
 
UnionConverter(SparkContext) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.converter.UnionConverter
 
UnionOnSchemaSetter - Class in org.apache.pig.newplan.logical.visitor
A visitor that modifies the logical plan (if necessary) for union-onschema functionality.
UnionOnSchemaSetter(OperatorPlan) - Constructor for class org.apache.pig.newplan.logical.visitor.UnionOnSchemaSetter
 
UnionOptimizer - Class in org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer
Optimizes union by removing the intermediate union vertex and making the successor get input from the predecessor vertices directly using VertexGroup.
UnionOptimizer(TezOperPlan, List<String>, List<String>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.UnionOptimizer
 
UniqueID - Class in org.apache.pig.builtin
UniqueID generates a unique id for each records in the job.
UniqueID() - Constructor for class org.apache.pig.builtin.UniqueID
 
UnixToISO - Class in org.apache.pig.piggybank.evaluation.datetime.convert
UnixToISO converts Unix Time Long datetimes to ISO8601 datetime strings
UnixToISO() - Constructor for class org.apache.pig.piggybank.evaluation.datetime.convert.UnixToISO
 
UNKNOWN - Static variable in class org.apache.pig.data.DataType
 
UNKNOWN - Static variable in class org.apache.pig.PigRunner.ReturnCode
 
UnlimitedNullTuple - Class in org.apache.pig.data
 
UnlimitedNullTuple() - Constructor for class org.apache.pig.data.UnlimitedNullTuple
 
unsetEntriesFromConfiguration(Configuration, Map<String, String>) - Method in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
Removes the given values from the configuration, accounting for changes in the Configuration API given the version of Hadoop being used.
unsetProjectionMap() - Method in class org.apache.pig.impl.plan.Operator
Unset the projection map as if it had not been calculated.
UNSIGNED_BYTE_MAX - Static variable in class org.apache.pig.data.BinInterSedes
 
UNSIGNED_SHORT_MAX - Static variable in class org.apache.pig.data.BinInterSedes
 
updateConfiguration(Properties) - Method in interface org.apache.pig.backend.datastorage.DataStorage
Provides a way to change configuration parameters at the Data Storage level.
updateConfiguration(Properties) - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
Update configuration information for this entity
updateConfiguration(Properties) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
updateConfiguration(Properties) - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
updateDepth(byte[], int, int) - Method in class org.apache.pig.impl.streaming.StreamingDelimiters
 
updateJobMroMap(Map<Job, MapReduceOper>) - Static method in class org.apache.pig.tools.pigstats.mapreduce.MRPigStatsUtil
Updates the PigStats.JobGraph of the PigStats.
updateLocalResourcesForInputSplits(FileSystem, InputSplitInfo, Map<String, LocalResource>) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.MRToTezHelper
Exact copy of private method from from org.apache.tez.mapreduce.hadoop.MRInputHelpers Update provided localResources collection with the required local resources needed by MapReduce tasks with respect to Input splits.
updateMappedColNames(Expression) - Method in class org.apache.pig.newplan.logical.rules.PartitionFilterOptimizer.PartitionFilterPushDownTransformer
 
updateMROpPlan(List<Job>) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
updatePlan(TezOperPlan, boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainer
 
updateSkipInterval(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
Update the average tuple size base on newly sampled tuple t and recalculate skipInterval
updateTop(PriorityQueue<Tuple>, int, DataBag) - Static method in class org.apache.pig.builtin.TOP
 
updateTop(PriorityQueue<Tuple>, int, DataBag) - Static method in class org.apache.pig.piggybank.evaluation.util.Top
Deprecated.
 
updateWithEmptyBagCheck(PhysicalPlan, Operator) - Static method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
updates plan with check for empty bag and if bag is empty to flatten a bag with as many null's as dictated by the schema
UPPER - Class in org.apache.pig.builtin
UPPER implements eval function to convert a string to upper case Example: A = load 'mydata' as (name); B = foreach A generate UPPER(name);
UPPER() - Constructor for class org.apache.pig.builtin.UPPER
 
UPPER - Class in org.apache.pig.piggybank.evaluation.string
Deprecated.
Use UPPER
UPPER() - Constructor for class org.apache.pig.piggybank.evaluation.string.UPPER
Deprecated.
 
UriUtil - Class in org.apache.pig.impl.util
 
UriUtil() - Constructor for class org.apache.pig.impl.util.UriUtil
 
usage() - Static method in class org.apache.pig.Main
Print usage string.
USED_BYTES_KEY - Static variable in interface org.apache.pig.backend.datastorage.DataStorage
 
useLog - Static variable in class org.apache.pig.impl.io.InterStorage
 
useLog - Static variable in class org.apache.pig.impl.io.SequenceFileInterStorage
 
useLog - Static variable in class org.apache.pig.impl.io.TFileStorage
 
user - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
USER_COMPARATOR_MARKER - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
USER_COMPARATOR_MARKER - Static variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
USER_ENVIRONMENT - Static variable in exception org.apache.pig.PigException
 
UserFuncExpression - Class in org.apache.pig.newplan.logical.expression
 
UserFuncExpression(OperatorPlan, FuncSpec) - Constructor for class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
UserFuncExpression(OperatorPlan, FuncSpec, List<LogicalExpression>) - Constructor for class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
UserFuncExpression(OperatorPlan, FuncSpec, boolean) - Constructor for class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
UserFuncExpression(OperatorPlan, FuncSpec, List<LogicalExpression>, boolean) - Constructor for class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
UserFuncExpression(OperatorPlan, FuncSpec, List<LogicalExpression>, boolean, boolean, boolean, String, String) - Constructor for class org.apache.pig.newplan.logical.expression.UserFuncExpression
 
userId - Variable in class org.apache.pig.tools.pigstats.PigStats
 
useTypedComparator(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
useTypedComparator(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
usingTypedComparator() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
usingTypedComparator() - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
UTF8 - Static variable in class org.apache.pig.data.BinInterSedes
 
UTF8 - Static variable in class org.apache.pig.data.DataReaderWriter
 
Utf8StorageConverter - Class in org.apache.pig.builtin
This abstract class provides standard conversions between utf8 encoded data and pig data types.
Utf8StorageConverter() - Constructor for class org.apache.pig.builtin.Utf8StorageConverter
 
Util - Class in org.apache.pig.newplan.logical
 
Util() - Constructor for class org.apache.pig.newplan.logical.Util
 
Util - Class in org.apache.pig.piggybank.evaluation.math
base class for math udfs
Util() - Constructor for class org.apache.pig.piggybank.evaluation.math.Util
 
Utils - Class in org.apache.pig.backend.hadoop.accumulo
 
Utils() - Constructor for class org.apache.pig.backend.hadoop.accumulo.Utils
 
Utils - Class in org.apache.pig.impl.util
Class with utility static methods
Utils() - Constructor for class org.apache.pig.impl.util.Utils
 

V

validate(LogicalSchema) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
Check if schema is valid (ready to be part of a final logical plan)
validate(PigContext, String, boolean) - Method in class org.apache.pig.newplan.logical.relational.LogicalPlan
 
validate() - Method in interface org.apache.pig.newplan.logical.rules.LogicalRelationalNodeValidator
Validates logical operators as defined in the logical plan of a pig script.
validate(LogicalRelationalOperator) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
The logic here is to check if we have duplicate alias in each schema
validate(String) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
 
validate(PigCommandFilter.Command) - Method in class org.apache.pig.validator.BlackAndWhitelistFilter
 
validate() - Method in class org.apache.pig.validator.BlackAndWhitelistValidator
 
validate(PigCommandFilter.Command) - Method in interface org.apache.pig.validator.PigCommandFilter
Validates a Pig command as defined by PigCommandFilter.Command.
validateAndConvert(Schema, ResourceSchema) - Static method in class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
Validate whether pigSchema is compatible with avroSchema
validateAndConvert(Schema, ResourceSchema.ResourceFieldSchema) - Static method in class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
Validate whether pigSchema is compatible with avroSchema and convert those Pig fields with to corresponding Avro schemas.
validateAndConvertRecord(Schema, ResourceSchema.ResourceFieldSchema[]) - Static method in class org.apache.pig.piggybank.storage.avro.PigSchema2Avro
Validate a Pig tuple is compatible with Avro record.
validateMapSideMerge(List<Operator>, OperatorPlan) - Method in class org.apache.pig.newplan.logical.relational.MapSideMergeValidator
 
validatePigProperties(Properties) - Static method in class org.apache.pig.impl.util.ConfigurationValidator
All pig configurations should be validated in here before use
valType - Variable in class org.apache.pig.piggybank.storage.SequenceFileLoader
 
VALUELIST - Class in org.apache.pig.builtin
This UDF takes a Map and returns a Bag containing the values from map.
VALUELIST() - Constructor for class org.apache.pig.builtin.VALUELIST
 
valueOf(String) - Static method in enum org.apache.pig.backend.datastorage.SeekableInputStream.FLAGS
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.backend.executionengine.ExecJob.JOB_STATUS
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.backend.hadoop.accumulo.Column.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager.PackageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.backend.hadoop.executionengine.spark.SparkLauncher.ResourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTezFactory.LocalRearrangeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.OPER_FEATURE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.data.SchemaTupleClassGenerator.GenContext
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.EvalFunc.SchemaType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.Expression.OpType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.impl.plan.CompilationMessageCollector.MessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.impl.plan.CompilationMessageCollector.Unknown
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.impl.streaming.InputHandler.InputType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.impl.streaming.OutputHandler.OutputType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.impl.streaming.StreamingCommand.Handle
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.impl.util.UDFContextSeparator.UDFType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.LoadPushDown.OperatorSet
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.newplan.logical.relational.LOCogroup.GROUPTYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.newplan.logical.relational.LogicalSchema.MergeMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.newplan.logical.relational.LOJoin.JOINTYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.newplan.logical.relational.LOLoad.CastState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.newplan.logical.relational.LOStream.CastState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.PigCounters
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.piggybank.evaluation.xml.XPathAll.ARGUMENTS
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.piggybank.storage.CSVExcelStorage.Headers
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.piggybank.storage.CSVExcelStorage.Linebreaks
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.piggybank.storage.CSVExcelStorage.Multiline
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.PigWarning
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.ResourceSchema.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.scripting.ScriptEngine.SupportedScriptLang
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.SortColInfo.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.tools.cmdline.CmdLineParser.ValueExpected
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.tools.pigstats.InputStats.INPUT_TYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.tools.pigstats.JobStats.JobState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.tools.pigstats.ScriptState.PIG_FEATURE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.tools.pigstats.ScriptState.PIG_PROPERTY
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.validator.PigCommandFilter.Command
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.pig.backend.datastorage.SeekableInputStream.FLAGS
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.backend.executionengine.ExecJob.JOB_STATUS
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.backend.hadoop.accumulo.Column.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.Packager.PackageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.backend.hadoop.executionengine.spark.SparkLauncher.ResourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTezFactory.LocalRearrangeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.OPER_FEATURE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.data.SchemaTupleClassGenerator.GenContext
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.EvalFunc.SchemaType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.Expression.OpType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.impl.plan.CompilationMessageCollector.MessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.impl.plan.CompilationMessageCollector.Unknown
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.impl.streaming.InputHandler.InputType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.impl.streaming.OutputHandler.OutputType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.impl.streaming.StreamingCommand.Handle
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.pig.impl.util.avro.AvroMapWrapper
 
values() - Method in class org.apache.pig.impl.util.MultiMap
Get a single collection of all the values in the map.
values() - Static method in enum org.apache.pig.impl.util.UDFContextSeparator.UDFType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.LoadPushDown.OperatorSet
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.newplan.logical.relational.LOCogroup.GROUPTYPE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.newplan.logical.relational.LogicalSchema.MergeMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.newplan.logical.relational.LOJoin.JOINTYPE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.newplan.logical.relational.LOLoad.CastState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.newplan.logical.relational.LOStream.CastState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.PigCounters
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.piggybank.evaluation.xml.XPathAll.ARGUMENTS
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.piggybank.storage.CSVExcelStorage.Headers
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.piggybank.storage.CSVExcelStorage.Linebreaks
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.piggybank.storage.CSVExcelStorage.Multiline
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.PigWarning
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.ResourceSchema.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.scripting.ScriptEngine.SupportedScriptLang
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.SortColInfo.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.tools.cmdline.CmdLineParser.ValueExpected
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.tools.pigstats.InputStats.INPUT_TYPE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.tools.pigstats.JobStats.JobState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.tools.pigstats.ScriptState.PIG_FEATURE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.tools.pigstats.ScriptState.PIG_PROPERTY
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.pig.validator.PigCommandFilter.Command
Returns an array containing the constants of this enum type, in the order they are declared.
VALUESET - Class in org.apache.pig.builtin
This UDF takes a Map and returns a Tuple containing the value set.
VALUESET() - Constructor for class org.apache.pig.builtin.VALUESET
 
verifyInput(Tuple, int) - Method in class org.apache.pig.TypedOutputEvalFunc
 
verifyUdfInput(String, Tuple, int) - Static method in class org.apache.pig.TypedOutputEvalFunc
Increment Hadoop counters for bad inputs which are either null or too small.
VertexGroupInfo() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
VertexGroupInfo(POStore) - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator.VertexGroupInfo
 
VISIBLE_FILES - Static variable in class org.apache.pig.impl.util.Utils
A PathFilter that filters out invisible files.
visit(MROpPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
visit(MROpPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.NativeMapReduceOper
 
visit(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visit(PlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter.InnerOperator
 
visit() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SampleOptimizer
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.EqualToExpr
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GreaterThanExpr
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GTOrEqualToExpr
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LessThanExpr
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LTOrEqualToExpr
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Mod
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.NotEqualToExpr
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POAnd
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POIsNull
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONot
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POOr
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORegexp
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORelationToExprProject
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
visit(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visit() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
visit() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.XMLPhysicalPlanPrinter
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POBroadcastSpark
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCollectedGroup
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCounter
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCross
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFilter
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLimit
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeCogroup
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMergeJoin
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PONative
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POOptimizedForEach
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPartialAgg
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPoissonSample
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORank
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POReservoirSample
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSkewedJoin
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POJoinGroupSpark
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.operator.POSampleSortSpark
 
visit(PlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.DotSparkPrinter.InnerOperator
 
visit(SparkOpPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOperator
 
visit(TezOpPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.NativeTezOper
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterStatsTez
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POCounterTez
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.PORankTez
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POShuffledValueInputTez
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueInputTez
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez
 
visit(TezOpPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOperator
 
visit(TezPlanContainerVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerNode
 
visit(V) - Method in class org.apache.pig.impl.plan.Operator
Visit this node with the provided visitor.
visit() - Method in class org.apache.pig.impl.plan.PlanVisitor
Entry point for visiting the plan.
visit() - Method in class org.apache.pig.newplan.FilterExtractor
 
visit(AndExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(OrExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(EqualExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(ProjectExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(ConstantExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(CastExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(GreaterThanExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(GreaterThanEqualExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(LessThanExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(LessThanEqualExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(NotEqualExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(NotExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(IsNullExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(NegativeExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(AddExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(SubtractExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(MultiplyExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(ModExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(DivideExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(MapLookupExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(BinCondExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(UserFuncExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(DereferenceExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(RegexExpression) - Method in class org.apache.pig.newplan.logical.expression.AllSameExpressionVisitor
 
visit(AndExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(OrExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(EqualExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(NotEqualExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(GreaterThanExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(GreaterThanEqualExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(LessThanExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(LessThanEqualExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(ProjectExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(MapLookupExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(ConstantExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(CastExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(NotExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(IsNullExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(NegativeExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(AddExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(RegexExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(SubtractExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(MultiplyExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(DivideExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(ModExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(BinCondExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(UserFuncExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(DereferenceExpression) - Method in class org.apache.pig.newplan.logical.expression.ExpToPhyTranslationVisitor
 
visit(AndExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(OrExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(EqualExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(ProjectExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(ConstantExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(CastExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(GreaterThanExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(GreaterThanEqualExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(LessThanExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(LessThanEqualExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(NotEqualExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(NotExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(IsNullExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(NegativeExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(AddExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(SubtractExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(MultiplyExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(ModExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(DivideExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(MapLookupExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(BinCondExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(UserFuncExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(DereferenceExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(RegexExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(ScalarExpression) - Method in class org.apache.pig.newplan.logical.expression.LogicalExpressionVisitor
 
visit(LOFilter) - Method in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
visit(LOLimit) - Method in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
visit(LOJoin) - Method in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
visit(LOCube) - Method in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
visit(LOCogroup) - Method in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
visit(LOGenerate) - Method in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
visit(LOInnerLoad) - Method in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
visit(LORank) - Method in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
visit(LOSort) - Method in class org.apache.pig.newplan.logical.optimizer.AllExpressionVisitor
 
visit(LOFilter) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOJoin) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOCogroup) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOLoad) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOSplit) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOUnion) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOSort) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LORank) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LODistinct) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOCross) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOStream) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOLimit) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LONative) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit(LOCube) - Method in class org.apache.pig.newplan.logical.optimizer.AllSameRalationalNodesVisitor
 
visit() - Method in class org.apache.pig.newplan.logical.optimizer.LogicalPlanPrinter
 
visit(LOLoad) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOFilter) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOJoin) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOGenerate) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOInnerLoad) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOCube) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOCogroup) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOSplit) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOSplitOutput) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOUnion) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOSort) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LORank) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LODistinct) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOLimit) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOCross) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOStream) - Method in class org.apache.pig.newplan.logical.optimizer.SchemaResetter
 
visit(LOLoad) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOFilter) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOJoin) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOGenerate) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOInnerLoad) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOCogroup) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOSplit) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOSplitOutput) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOUnion) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOSort) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LORank) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LODistinct) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOLimit) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOCross) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOStream) - Method in class org.apache.pig.newplan.logical.optimizer.UidResetter
 
visit(LOLoad) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOFilter) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOJoin) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOGenerate) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOInnerLoad) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOCube) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOCogroup) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOSplit) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOUnion) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOSort) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LORank) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LODistinct) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOLimit) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOCross) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOStream) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LONative) - Method in class org.apache.pig.newplan.logical.relational.LogicalRelationalNodesVisitor
 
visit(LOLoad) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LONative) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOFilter) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOSort) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LORank) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
Transformation from Logical to Physical Plan involves the following steps: First, it is generated a random number which will link a POCounter within a PORank.
visit(LOCross) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOStream) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOInnerLoad) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOCogroup) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOJoin) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOUnion) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LODistinct) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOLimit) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOSplit) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.newplan.logical.relational.LogToPhyTranslationVisitor
 
visit(LOLoad) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LOFilter) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LOLimit) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LOSplit) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LOSort) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LORank) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LOCogroup) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LOJoin) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LOCross) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LOUnion) - Method in class org.apache.pig.newplan.logical.rules.ColumnPruneVisitor
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.FullMapCollector
 
visit(LOUnion) - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.FullMapCollector
 
visit(LOCogroup) - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.FullMapCollector
 
visit(LOSplitOutput) - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.FullMapCollector
 
visit(LOLoad) - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.MapMarker
 
visit(LOFilter) - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.MapMarker
 
visit(LOJoin) - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.MapMarker
 
visit(LOGenerate) - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.MapMarker
 
visit(LOSort) - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.MapMarker
 
visit(LOSplitOutput) - Method in class org.apache.pig.newplan.logical.rules.MapKeysPruneHelper.MapMarker
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.visitor.DanglingNestedNodeRemover
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.visitor.DuplicateForEachColumnRewriteVisitor
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.visitor.ForEachUserSchemaVisitor
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.visitor.InputOutputFileValidatorVisitor
 
visit(LOLoad) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOStream) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOInnerLoad) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOFilter) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOCogroup) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOJoin) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOGenerate) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOSort) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LORank) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LODistinct) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOLimit) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOSplit) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOCross) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOUnion) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.newplan.logical.visitor.LineageFindRelVisitor
 
visit(LOSort) - Method in class org.apache.pig.newplan.logical.visitor.ProjectStarExpander
 
visit(LORank) - Method in class org.apache.pig.newplan.logical.visitor.ProjectStarExpander
 
visit(LOCogroup) - Method in class org.apache.pig.newplan.logical.visitor.ProjectStarExpander
 
visit(LOCube) - Method in class org.apache.pig.newplan.logical.visitor.ProjectStarExpander
 
visit(LOJoin) - Method in class org.apache.pig.newplan.logical.visitor.ProjectStarExpander
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.visitor.ProjectStarExpander
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.visitor.ProjStarInUdfExpander
 
visit(LOGenerate) - Method in class org.apache.pig.newplan.logical.visitor.ProjStarInUdfExpander
 
visit(ProjectExpression) - Method in class org.apache.pig.newplan.logical.visitor.ResetProjectionAttachedRelationalOpVisitor
 
visit(ProjectExpression) - Method in class org.apache.pig.newplan.logical.visitor.ScalarVariableValidator.ProjectFinder
 
visit(LOLimit) - Method in class org.apache.pig.newplan.logical.visitor.ScalarVariableValidator
 
visit(LOFilter) - Method in class org.apache.pig.newplan.logical.visitor.ScalarVariableValidator
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOFilter) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOJoin) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOGenerate) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOInnerLoad) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOCogroup) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOSplit) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOUnion) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOSort) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LORank) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LODistinct) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOLimit) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOCross) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOStream) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LONative) - Method in class org.apache.pig.newplan.logical.visitor.SchemaAliasVisitor
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.visitor.SortInfoSetter
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.visitor.StoreAliasSetter
 
visit(AddExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(SubtractExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(MultiplyExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(DivideExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(ModExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(NegativeExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(NotExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(OrExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(AndExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(LessThanExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(LessThanEqualExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(GreaterThanExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(GreaterThanEqualExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(EqualExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(NotEqualExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(CastExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
For Basic Types: 0) Casting to itself is always ok 1) Casting from number to number is always ok 2) ByteArray to anything is ok 3) number to chararray is ok For Composite Types: Recursively traverse the schemas till you get a basic type
visit(RegexExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
RegexExpression expects CharArray as input Itself always returns Boolean
visit(BinCondExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(MapLookupExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(DereferenceExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(UserFuncExpression) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingExpVisitor
 
visit(LOLoad) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
 
visit(LOStore) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
 
visit(LOFilter) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
The schema of filter output will be the same as filter input
visit(LOGenerate) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
 
visit(LOInnerLoad) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
 
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
 
visit(LOUnion) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
 
visit(LODistinct) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
LODistinct, output schema should be the same as input
visit(LOLimit) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
 
visit(LOCross) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
Return concatenated of all fields from all input operators If one of the inputs have no schema then we cannot construct the output schema.
visit(LOSort) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
The schema of sort output will be the same as sort input.
visit(LORank) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
The schema of rank output will be the same as input, plus a rank field.
visit(LOSplit) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
The schema of split output will be the same as split input
visit(LOJoin) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
LOJoin visitor
visit(LOCogroup) - Method in class org.apache.pig.newplan.logical.visitor.TypeCheckingRelVisitor
COGroup All group by cols from all inputs have to be of the same type
visit(LOForEach) - Method in class org.apache.pig.newplan.logical.visitor.UDFFinder
 
visit(LOGenerate) - Method in class org.apache.pig.newplan.logical.visitor.UDFFinder
 
visit(LOUnion) - Method in class org.apache.pig.newplan.logical.visitor.UnionOnSchemaSetter
 
visit() - Method in class org.apache.pig.newplan.PlanVisitor
Entry point for visiting the plan.
visit() - Method in class org.apache.pig.newplan.PredicatePushDownFilterExtractor
 
visit(LOCogroup) - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
visit(LOJoin) - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
visit(LOCross) - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
visit(LODistinct) - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
visit(LOFilter) - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
visit(LOForEach) - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
visit(LOLoad) - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
visit(LOSort) - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
visit(LOSplit) - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
visit(LOStore) - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
visit(LOUnion) - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
visit(LOLimit) - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
visit(LOCogroup) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LOJoin) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LOCross) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LODistinct) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LOFilter) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LOStore) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LOForEach) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LOLimit) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LOLoad) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LOSort) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LOSplit) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LOUnion) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
visit(LOJoin) - Method in class org.apache.pig.pen.POOptimizeDisabler
 
visit(LOCogroup) - Method in class org.apache.pig.pen.POOptimizeDisabler
 
visit(JobStats) - Method in class org.apache.pig.tools.pigstats.PigStats.JobGraphPrinter
 
visitAdd(Add) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitAdd(Add) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitAnd(POAnd) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitAnd(POAnd) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitAnd(POAnd) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitBinCond(POBinCond) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitBinCond(POBinCond) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitBinCond(POBinCond) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitBroadcastSpark(POBroadcastSpark) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitCast(POCast) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitCast(POCast) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.UDFFinder
 
visitCast(POCast) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitCast(POCast) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.UdfCacheShipFilesVisitor
 
visitCast(POCast) - Method in class org.apache.pig.impl.util.UDFContextSeparator
 
visitCast(POCast) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitCollectedGroup(POCollectedGroup) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitCollectedGroup(POCollectedGroup) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitCollectedGroup(POCollectedGroup) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter.EndOfAllInputChecker
 
visitCollectedGroup(POCollectedGroup) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitCollectedGroup(POCollectedGroup) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitCollectedGroup(POCollectedGroup) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitCollectedGroup(POCollectedGroup) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitCollectedGroup(POCollectedGroup) - Method in class org.apache.pig.tools.pigstats.ScriptState.FeatureVisitor
 
visitComparisonFunc(POUserComparisonFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitComparisonFunc(POUserComparisonFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.UDFFinder
 
visitComparisonFunc(POUserComparisonFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitComparisonFunc(POUserComparisonFunc) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitConstant(ConstantExpression) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitConstant(ConstantExpression) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitConstant(ConstantExpression) - Method in class org.apache.pig.backend.hadoop.executionengine.util.ParallelConstantVisitor
 
visitCounter(POCounter) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
For the counter job, it depends if it is row number or not.
visitCounter(POCounter) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitCounter(POCounter) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitCounter(POCounter) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitCounter(POCounter) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitCross(POCross) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitCross(POCross) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitCross(POCross) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitCross(POCross) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitDemux(PODemux) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitDemux(PODemux) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitDemux(PODemux) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitDemux(PODemux) - Method in class org.apache.pig.tools.pigstats.ScriptState.FeatureVisitor
 
visitDistinct(PODistinct) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitDistinct(PODistinct) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitDistinct(PODistinct) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitDistinct(PODistinct) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitDistinct(PODistinct) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitDistinct(PODistinct) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitDistinct(PODistinct) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitDistinct(PODistinct) - Method in class org.apache.pig.tools.pigstats.ScriptState.FeatureVisitor
 
visitDivide(Divide) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitDivide(Divide) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitEqualTo(EqualToExpr) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitEqualTo(EqualToExpr) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitEqualTo(EqualToExpr) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitFilter(POFilter) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitFilter(POFilter) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitFilter(POFilter) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitFilter(POFilter) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
visitFilter(POFilter) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitFilter(POFilter) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezOperDependencyParallelismEstimator.TezParallelismFactorVisitor
 
visitFilter(POFilter) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitFilter(POFilter) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitFilter(POFilter) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitFRJoin(POFRJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
This is an operator which will have multiple inputs(= to number of join inputs) But it prunes off all inputs but the fragment input and creates separate MR jobs for each of the replicated inputs and uses these as the replicated files that are configured in the POFRJoin operator.
visitFRJoin(POFRJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitFRJoin(POFRJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitFRJoin(POFRJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitFRJoin(POFRJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezOperDependencyParallelismEstimator.TezParallelismFactorVisitor
 
visitFRJoin(POFRJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitFRJoin(POFRJoin) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitFRJoin(POFRJoin) - Method in class org.apache.pig.tools.pigstats.ScriptState.FeatureVisitor
 
visitGlobalRearrange(POGlobalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitGlobalRearrange(POGlobalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitGlobalRearrange(POGlobalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitGlobalRearrange(POGlobalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
visitGlobalRearrange(POGlobalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitGlobalRearrange(POGlobalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitGreaterThan(GreaterThanExpr) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitGreaterThan(GreaterThanExpr) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitGreaterThan(GreaterThanExpr) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitGTOrEqual(GTOrEqualToExpr) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitGTOrEqual(GTOrEqualToExpr) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitGTOrEqual(GTOrEqualToExpr) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitIsNull(POIsNull) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitIsNull(POIsNull) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitIsNull(POIsNull) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitLessThan(LessThanExpr) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitLessThan(LessThanExpr) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitLessThan(LessThanExpr) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitLimit(POLimit) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitLimit(POLimit) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitLimit(POLimit) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitLimit(POLimit) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitLimit(POLimit) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezOperDependencyParallelismEstimator.TezParallelismFactorVisitor
 
visitLimit(POLimit) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitLimit(POLimit) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitLimit(POLimit) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitLoad(POLoad) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitLoad(POLoad) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitLoad(POLoad) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitLoad(POLoad) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
visitLoad(POLoad) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.UdfCacheShipFilesVisitor
 
visitLoad(POLoad) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitLoad(POLoad) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitLoad(POLoad) - Method in class org.apache.pig.impl.util.UDFContextSeparator
 
visitLoad(POLoad) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitLoad(POLoad) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitLocalRearrange(POLocalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitLocalRearrange(POLocalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitLocalRearrange(POLocalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter.EndOfAllInputChecker
 
visitLocalRearrange(POLocalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitLocalRearrange(POLocalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
visitLocalRearrange(POLocalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitLocalRearrange(POLocalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitLocalRearrange(POLocalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOPackageAnnotator.LoRearrangeDiscoverer
 
visitLocalRearrange(POLocalRearrange) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitLocalRearrange(POLocalRearrange) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitLTOrEqual(LTOrEqualToExpr) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitLTOrEqual(LTOrEqualToExpr) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitLTOrEqual(LTOrEqualToExpr) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitMapLookUp(POMapLookUp) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitMapLookUp(POMapLookUp) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitMapLookUp(POMapLookUp) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitMergeCoGroup(POMergeCogroup) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
Leftmost relation is referred as base relation (this is the one fed into mappers.) First, close all MROpers except for first one (referred as baseMROPer) Then, create a MROper which will do indexing job (idxMROper) Connect idxMROper before the mappedMROper in the MRPlan.
visitMergeCoGroup(POMergeCogroup) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitMergeCoGroup(POMergeCogroup) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter.EndOfAllInputChecker
 
visitMergeCoGroup(POMergeCogroup) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitMergeCoGroup(POMergeCogroup) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitMergeCoGroup(POMergeCogroup) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitMergeCoGroup(POMergeCogroup) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitMergeCoGroup(POMergeCogroup) - Method in class org.apache.pig.tools.pigstats.ScriptState.FeatureVisitor
 
visitMergeJoin(POMergeJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
Since merge-join works on two inputs there are exactly two MROper predecessors identified as left and right.
visitMergeJoin(POMergeJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitMergeJoin(POMergeJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter.EndOfAllInputChecker
 
visitMergeJoin(POMergeJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitMergeJoin(POMergeJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitMergeJoin(POMergeJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezOperDependencyParallelismEstimator.TezParallelismFactorVisitor
 
visitMergeJoin(POMergeJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
Since merge-join works on two inputs there are exactly two TezOper predecessors identified as left and right.
visitMergeJoin(POMergeJoin) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitMergeJoin(POMergeJoin) - Method in class org.apache.pig.tools.pigstats.ScriptState.FeatureVisitor
 
visitMod(Mod) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitMod(Mod) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.AccumulatorOptimizer
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.CombinerOptimizer
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.KeyTypeDiscoveryVisitor
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.LimitAdjuster
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.MRIntermediateDataVisitor
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.MROpPlanVisitor
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.MRPrinter
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.POPackageAnnotator
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.XMLMRPrinter
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SampleOptimizer
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SecondaryKeyOptimizer
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SecondaryKeyOptimizerMR
 
visitMultiply(Multiply) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitMultiply(Multiply) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitNative(PONative) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitNative(PONative) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitNative(PONative) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitNative(PONative) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitNative(PONative) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitNegative(PONegative) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitNegative(PONegative) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitNegative(PONegative) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitNot(PONot) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitNot(PONot) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitNot(PONot) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitNotEqualTo(NotEqualToExpr) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitNotEqualTo(NotEqualToExpr) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitNotEqualTo(NotEqualToExpr) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitOr(POOr) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitOr(POOr) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitOr(POOr) - Method in class org.apache.pig.pen.IllustratorAttacher
 
VisitorException - Exception in org.apache.pig.impl.plan
 
VisitorException() - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with null as the error message.
VisitorException(String) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message and cause.
VisitorException(Operator, String) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message and cause.
VisitorException(Throwable) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified cause.
VisitorException(String, Throwable) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message and cause.
VisitorException(String, int) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message and cause.
VisitorException(Operator, String, int) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message and cause.
VisitorException(String, int, Throwable) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message and cause.
VisitorException(String, int, byte) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message and cause.
VisitorException(Operator, String, int, byte) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message and cause.
VisitorException(String, int, byte, Throwable) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message and cause.
VisitorException(Operator, String, int, byte, Throwable) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message and cause.
VisitorException(String, int, boolean) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message and cause.
VisitorException(String, int, byte, boolean) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message and cause.
VisitorException(String, int, byte, boolean, String) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
VisitorException(String, int, byte, boolean, String, Throwable) - Constructor for exception org.apache.pig.impl.plan.VisitorException
Create a new VisitorException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
visitPackage(POPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitPackage(POPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitPackage(POPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitPackage(POPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
visitPackage(POPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitPackage(POPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezOperDependencyParallelismEstimator.TezParallelismFactorVisitor
 
visitPackage(POPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitPackage(POPackage) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitPackage(POPackage) - Method in class org.apache.pig.pen.PhysicalPlanResetter
 
visitPartialAgg(POPartialAgg) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitPartialAgg(POPartialAgg) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter.EndOfAllInputChecker
 
visitPartialAgg(POPartialAgg) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitPartialAgg(POPartialAgg) - Method in class org.apache.pig.tools.pigstats.ScriptState.FeatureVisitor
 
visitPartitionRearrange(POPartitionRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitPOForEach(POForEach) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitPOForEach(POForEach) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitPOForEach(POForEach) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter.EndOfAllInputChecker
 
visitPOForEach(POForEach) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitPOForEach(POForEach) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitPOForEach(POForEach) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezOperDependencyParallelismEstimator.TezParallelismFactorVisitor
 
visitPOForEach(POForEach) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitPOForEach(POForEach) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitPOForEach(POForEach) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitPoissonSample(POPoissonSample) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitPoissonSample(POPoissonSample) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter.EndOfAllInputChecker
 
visitPoissonSample(POPoissonSample) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitPOOptimizedForEach(POOptimizedForEach) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitPOOptimizedForEach(POOptimizedForEach) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitPOOptimizedForEach(POOptimizedForEach) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitPreCombinerLocalRearrange(POPreCombinerLocalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitPreCombinerLocalRearrange(POPreCombinerLocalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitProject(POProject) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitProject(POProject) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitProject(POProject) - Method in class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil.DistinctPatcher
 
visitProject(POProject) - Method in class org.apache.pig.backend.hadoop.executionengine.util.CombinerOptimizerUtil.fixMapProjects
 
visitProject(POProject) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitRank(PORank) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
In case of PORank, it is closed any other previous job (containing POCounter as a leaf) and PORank is added on map phase.
visitRank(PORank) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitRank(PORank) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitRank(PORank) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitRank(PORank) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitRank(PORank) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitRegexp(PORegexp) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitRegexp(PORegexp) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitRegexp(PORegexp) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitReservoirSample(POReservoirSample) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitReservoirSample(POReservoirSample) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter.EndOfAllInputChecker
 
visitReservoirSample(POReservoirSample) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitSkewedJoin(POSkewedJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitSkewedJoin(POSkewedJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitSkewedJoin(POSkewedJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitSkewedJoin(POSkewedJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
currently use regular join to replace skewedJoin Skewed join currently works with two-table inner join.
visitSkewedJoin(POSkewedJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitSkewedJoin(POSkewedJoin) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitSort(POSort) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitSort(POSort) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitSort(POSort) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.UDFFinder
 
visitSort(POSort) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitSort(POSort) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitSort(POSort) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitSort(POSort) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitSort(POSort) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobGraphBuilder
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.AccumulatorOptimizer
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.CombinerOptimizer
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.JoinGroupOptimizerSpark
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.MultiQueryOptimizerSpark
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.NoopFilterRemover
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.ParallelismSetter
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.optimizer.SecondaryKeyOptimizerSpark
Secondary key sort optimization is enabled in group + foreach nested situation, like TestAccumlator#testAccumWithSort After calling SecondaryKeyOptimizerUtil.applySecondaryKeySort, the POSort in the POForeach will be deleted in the spark plan.
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkOpPlanVisitor
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkPOPackageAnnotator
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkPrinter
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.XMLSparkPrinter
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPOUserFuncVisitor
 
visitSparkOp(SparkOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.UDFJarsFinder
 
visitSplit(POSplit) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
Compiles a split operator.
visitSplit(POSplit) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitSplit(POSplit) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitSplit(POSplit) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitSplit(POSplit) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezOperDependencyParallelismEstimator.TezParallelismFactorVisitor
 
visitSplit(POSplit) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitSplit(POSplit) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOPackageAnnotator.LoRearrangeDiscoverer
 
visitSplit(POSplit) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitSplit(POSplit) - Method in class org.apache.pig.tools.pigstats.ScriptState.FeatureVisitor
 
visitStartMap(POUnion) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
visitStore(POStore) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitStore(POStore) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitStore(POStore) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitStore(POStore) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
visitStore(POStore) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.UdfCacheShipFilesVisitor
 
visitStore(POStore) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitStore(POStore) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitStore(POStore) - Method in class org.apache.pig.impl.util.UDFContextSeparator
 
visitStore(POStore) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitStream(POStream) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitStream(POStream) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitStream(POStream) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.EndOfAllInputSetter.EndOfAllInputChecker
 
visitStream(POStream) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitStream(POStream) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitStream(POStream) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitStream(POStream) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitStream(POStream) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitStream(POStream) - Method in class org.apache.pig.tools.pigstats.ScriptState.FeatureVisitor
 
visitSubtract(Subtract) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitSubtract(Subtract) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.AccumulatorOptimizer
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.CombinerOptimizer
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.LoaderProcessor
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.MultiQueryOptimizerTez
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.NoopFilterRemover
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.ParallelismSetter
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.SecondaryKeyOptimizerTez
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.TezEstimatedParallelismClearer
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.optimizer.UnionOptimizer
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezOpPlanVisitor
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOPackageAnnotator
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOStreamVisitor
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPOUserFuncVisitor
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPrinter.TezVertexGraphPrinter
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPrinter
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.TezDagBuilder
 
visitTezOp(TezOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.util.TezUDFContextSeparator
 
visitTezPlanContainerNode(TezPlanContainerNode) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerPrinter
 
visitTezPlanContainerNode(TezPlanContainerNode) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerUDFCollector
 
visitTezPlanContainerNode(TezPlanContainerNode) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPlanContainerVisitor
 
visitTezPlanContainerNode(TezPlanContainerNode) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPrinter.TezDAGGraphPrinter
 
visitUnion(POUnion) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
visitUnion(POUnion) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitUnion(POUnion) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitUnion(POUnion) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.plan.SparkCompiler
 
visitUnion(POUnion) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezCompiler
 
visitUnion(POUnion) - Method in class org.apache.pig.pen.IllustratorAttacher
 
visitUnion(POUnion) - Method in class org.apache.pig.tools.pigstats.ScriptState.AliasVisitor
 
visitUserFunc(POUserFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitUserFunc(POUserFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.ScalarPhyFinder
 
visitUserFunc(POUserFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.UDFFinder
 
visitUserFunc(POUserFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.UDFEndOfAllInputNeededVisitor
 
visitUserFunc(POUserFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.UDFFinishVisitor
 
visitUserFunc(POUserFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitUserFunc(POUserFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.UdfCacheShipFilesVisitor
 
visitUserFunc(POUserFunc) - Method in class org.apache.pig.impl.util.UDFContextSeparator
 
visitUserFunc(POUserFunc) - Method in class org.apache.pig.pen.IllustratorAttacher
 
vSize - Variable in class org.apache.pig.builtin.BuildBloomBase
 

W

waitForJobAddStats(int, POStore, SparkOperator, JobMetricsListener, JavaSparkContext, SparkPigStats) - Static method in class org.apache.pig.tools.pigstats.spark.SparkStatsUtil
 
waitForJobToEnd(int) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.JobMetricsListener
 
walk(PlanVisitor<O, P>) - Method in class org.apache.pig.impl.plan.DependencyOrderWalker
Begin traversing the graph.
walk(PlanVisitor<O, P>) - Method in class org.apache.pig.impl.plan.DepthFirstWalker
Begin traversing the graph.
walk(PlanVisitor<O, P>) - Method in class org.apache.pig.impl.plan.PlanWalker
Begin traversing the graph.
walk(PlanVisitor<O, P>) - Method in class org.apache.pig.impl.plan.ReverseDependencyOrderWalker
Begin traversing the graph.
walk(PlanVisitor) - Method in class org.apache.pig.newplan.DependencyOrderWalker
Begin traversing the graph.
walk(PlanVisitor) - Method in class org.apache.pig.newplan.DepthFirstWalker
Begin traversing the graph.
walk(PlanVisitor) - Method in class org.apache.pig.newplan.PlanWalker
Begin traversing the graph.
walk(PlanVisitor) - Method in class org.apache.pig.newplan.ReverseDependencyOrderWalker
Begin traversing the graph.
walk(PlanVisitor) - Method in class org.apache.pig.newplan.ReverseDependencyOrderWalkerWOSeenChk
Begin traversing the graph.
walk(PlanVisitor) - Method in class org.apache.pig.newplan.SubtreeDependencyOrderWalker
 
walk(PlanVisitor) - Method in class org.apache.pig.pen.util.PreOrderDepthFirstWalker
Begin traversing the graph.
warn(Object, String, Enum) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigHadoopLogger
 
warn(Object, String, Enum<?>) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.PigLogger
If you have warning messages that need aggregation
warn(String, Enum, Throwable) - Method in class org.apache.pig.data.DefaultAbstractBag
 
warn(String, Enum) - Method in class org.apache.pig.EvalFunc
Issue a warning.
warn(Object, String, PigWarning, Log) - Static method in class org.apache.pig.impl.util.LogUtils
 
warn(String, Enum) - Method in class org.apache.pig.LoadFunc
Issue a warning.
warn(String, Enum) - Method in class org.apache.pig.StoreFunc
Issue a warning.
WeeksBetween - Class in org.apache.pig.builtin
WeeksBetween returns the number of weeks between two DateTime objects
WeeksBetween() - Constructor for class org.apache.pig.builtin.WeeksBetween
 
WEIGHTED_PARTS - Static variable in class org.apache.pig.impl.builtin.FindQuantiles
 
weightedParts - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
WeightedRangePartitioner - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners
 
WeightedRangePartitioner() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
WeightedRangePartitionerTez - Class in org.apache.pig.backend.hadoop.executionengine.tez.runtime
 
WeightedRangePartitionerTez() - Constructor for class org.apache.pig.backend.hadoop.executionengine.tez.runtime.WeightedRangePartitionerTez
 
WholePlanRule - Class in org.apache.pig.newplan.logical.rules
Super class for all rules that operates on the whole plan.
WholePlanRule(String, boolean) - Constructor for class org.apache.pig.newplan.logical.rules.WholePlanRule
 
withConf(Configuration) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
withGt(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
withGte(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
withLimit(long) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
withLt(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
withLte(byte[]) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseTableInputFormat.HBaseTableIFBuilder
 
WORK_OUPUT_DIR - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRConfiguration
 
wrap(Throwable) - Static method in class org.apache.pig.impl.util.WrappedIOException
Deprecated.
 
wrap(String, Throwable) - Static method in class org.apache.pig.impl.util.WrappedIOException
Deprecated.
 
wrapAsTuple(ResourceSchema.ResourceFieldSchema) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
wrap a pig schema as tuple
wrapAsTuple(Object) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroRecordReader
Wrap non-tuple value as a tuple
wrapAsUnion(Schema, boolean) - Static method in class org.apache.pig.piggybank.storage.avro.AvroStorageUtils
Wrap an avro schema as a nullable union if needed.
wrapped - Variable in class org.apache.pig.piggybank.storage.XMLLoader.XMLRecordReader
 
WrappedIOException - Class in org.apache.pig.impl.util
Deprecated.
This class was introduced to overcome the limitation that before Java 1.6, IOException did not have a constructor which took a Throwable argument. Since Pig code is now compiled with Java 1.6 and EvalFunc and LoadFunc user implementations should also use Java 1.6, they can use IOException instead. From Java 1.6, IOException has constructors which take a Throwable argument.
WrappedIOException() - Constructor for class org.apache.pig.impl.util.WrappedIOException
Deprecated.
 
WritableByteArray - Class in org.apache.pig.data
A reusable byte buffer implementation
WritableByteArray() - Constructor for class org.apache.pig.data.WritableByteArray
 
WritableByteArray(int) - Constructor for class org.apache.pig.data.WritableByteArray
 
WritableByteArray(byte[]) - Constructor for class org.apache.pig.data.WritableByteArray
 
write(int) - Method in class org.apache.pig.backend.datastorage.ImmutableOutputStream
 
write(int) - Method in class org.apache.pig.backend.hadoop.accumulo.FixedByteArrayOutputStream
 
write(byte[], int, int) - Method in class org.apache.pig.backend.hadoop.accumulo.FixedByteArrayOutputStream
 
write(DataOutput) - Method in class org.apache.pig.backend.hadoop.BigDecimalWritable
 
write(DataOutput) - Method in class org.apache.pig.backend.hadoop.BigIntegerWritable
 
write(DataOutput) - Method in class org.apache.pig.backend.hadoop.DateTimeWritable
 
write(DataOutput) - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
write(PigNullableWritable, Writable) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase.IllustratorContext
 
write(PigNullableWritable, Writable) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce.IllustratorContextImpl
 
write(WritableComparable, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat.PigRecordWriter
We only care about the values, so we are going to skip the keys when we write.
write(DataOutput) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
write(WritableComparable, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTextOutputFormat.PigLineRecordWriter
 
write(DataOutput) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.FileSparkPigSplit
 
write(DataOutput) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.SparkPigSplit.GenericSparkPigSplit
 
write(DataOutput) - Method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POValueOutputTez.EmptyWritable
 
write(DataOutput) - Method in class org.apache.pig.backend.hadoop.hbase.TableSplitComparable
 
write(DataOutput) - Method in class org.apache.pig.data.AccumulativeBag
 
write(DataOutput) - Method in class org.apache.pig.data.BinSedesTuple
 
write(DataOutput) - Method in class org.apache.pig.data.DefaultAbstractBag
Write a bag's contents to disk.
write(DataOutput) - Method in class org.apache.pig.data.DefaultTuple
 
write(DataOutput) - Method in class org.apache.pig.data.LimitedSortedDataBag
Write a bag's contents to disk.
write(DataOutput) - Method in class org.apache.pig.data.NonSpillableDataBag
Write a bag's contents to disk.
write(DataOutput) - Method in class org.apache.pig.data.ReadOnceBag
 
write(DataOutput, boolean) - Method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput, DataBag) - Static method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput, Map<String, Object>) - Static method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput, int) - Static method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput, long) - Static method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput, float) - Static method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput, double) - Static method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput, DateTime) - Static method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput, BigDecimal) - Static method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput, BigInteger) - Static method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput, byte[]) - Static method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput, String) - Static method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput, SchemaTuple<?>) - Static method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput) - Method in class org.apache.pig.data.SchemaTuple
 
write(DataOutput) - Method in class org.apache.pig.data.SingleTupleBag
 
write(DataOutput) - Method in class org.apache.pig.data.TargetedTuple
 
write(DataOutput) - Method in class org.apache.pig.data.UnlimitedNullTuple
 
write(DataOutput) - Method in class org.apache.pig.FileSplitComparable
 
write(WritableComparable, Tuple) - Method in class org.apache.pig.impl.io.BinStorageRecordWriter
 
write(WritableComparable, Tuple) - Method in class org.apache.pig.impl.io.InterRecordWriter
 
write(DataOutput) - Method in class org.apache.pig.impl.io.NullablePartitionWritable
 
write(DataOutput) - Method in class org.apache.pig.impl.io.PigNullableWritable
 
write(WritableComparable, Tuple) - Method in class org.apache.pig.impl.io.TFileRecordWriter
 
write(DataOutput) - Method in class org.apache.pig.impl.util.avro.AvroBagWrapper
 
write(NullWritable, Object) - Method in class org.apache.pig.impl.util.avro.AvroRecordWriter
 
write(DataOutput) - Method in class org.apache.pig.impl.util.avro.AvroTupleWrapper
 
write(int) - Method in class org.apache.pig.impl.util.HashOutputStream
 
write(DataOutput) - Method in class org.apache.pig.pen.util.ExampleTuple
 
write(Schema, Object, Encoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
 
write(NullWritable, Object) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroRecordWriter
 
write(NullWritable, Writable) - Method in class org.apache.pig.piggybank.storage.hiverc.HiveRCOutputFormat.Writer
 
write(WritableComparable, Tuple) - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexedStorageOutputFormat.IndexedStorageRecordWriter
 
WRITE_THREADS_OPTION - Static variable in class org.apache.pig.backend.hadoop.accumulo.AccumuloStorageOptions
 
writeBoolean(Object, Encoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
Write boolean.
writeBooleanArray(DataOutput, boolean[], boolean) - Static method in class org.apache.pig.data.utils.SedesHelper
 
writeBooleanArray(DataOutput, boolean[]) - Static method in class org.apache.pig.data.utils.SedesHelper
 
writeBytes(DataOutput, byte[]) - Static method in class org.apache.pig.data.utils.SedesHelper
 
writeBytes(Object, Encoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
Called to write a bytes.
writeChararray(DataOutput, String) - Static method in class org.apache.pig.data.utils.SedesHelper
 
writeDatum(DataOutput, Object) - Method in class org.apache.pig.data.BinInterSedes
 
writeDatum(DataOutput, Object, byte) - Method in class org.apache.pig.data.BinInterSedes
 
writeDatum(DataOutput, Object) - Static method in class org.apache.pig.data.DataReaderWriter
 
writeDatum(DataOutput, Object) - Method in interface org.apache.pig.data.InterSedes
Write given object val to DataOutput out
writeDatum(DataOutput, Object, byte) - Method in interface org.apache.pig.data.InterSedes
Write given object val of DataType type to DataOutput out
writeDouble(Object, Encoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
Write double.
writeElements(DataOutput) - Method in class org.apache.pig.data.AppendableSchemaTuple
 
writeElements(DataOutput) - Method in class org.apache.pig.data.SchemaTuple
This method is responsible for writing everything contained by the Tuple.
writeErrorToHDFS(int, String) - Method in class org.apache.pig.backend.hadoop.executionengine.spark.streaming.SparkExecutableManager
 
writeErrorToHDFS(int, String) - Method in class org.apache.pig.backend.hadoop.streaming.HadoopExecutableManager
Should the stderr data of this task be persisted on HDFS?
writeFixed(Schema, Object, Encoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
Called to write a fixed value.
writeFloat(Object, Encoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
Write float.
writeGenericTuple(DataOutput, Tuple) - Static method in class org.apache.pig.data.utils.SedesHelper
 
WriteIndex() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Writes the current index.
WriteIndexHeader() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Write index header
writeInputSplitInfoToDisk(InputSplitInfoMem, Path, JobConf, FileSystem) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.util.MRToTezHelper
Write input splits (job.split and job.splitmetainfo) to disk
writeLog(Throwable, String, Log, boolean, String) - Static method in class org.apache.pig.impl.util.LogUtils
 
writeLog(Throwable, String, Log, boolean, String, boolean, boolean) - Static method in class org.apache.pig.impl.util.LogUtils
 
writeLog(String, String, String, Log) - Static method in class org.apache.pig.impl.util.LogUtils
 
writeLong(Object, Encoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
Write long.
writePlan(TezPlanContainer, TezPlanContainerNode, StringBuilder) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPrinter.TezDAGGraphPrinter
 
writePlan(TezOperPlan, TezOperator, StringBuilder) - Static method in class org.apache.pig.backend.hadoop.executionengine.tez.plan.TezPrinter.TezVertexGraphPrinter
 
writer - Variable in class org.apache.pig.backend.hadoop.executionengine.tez.plan.operator.POLocalRearrangeTez
 
writer - Variable in class org.apache.pig.builtin.JsonStorage
 
writer - Variable in class org.apache.pig.builtin.OrcStorage
 
writer - Variable in class org.apache.pig.builtin.PigStorage
 
Writer(HiveRCOutputFormat, TaskAttemptContext, Text) - Constructor for class org.apache.pig.piggybank.storage.hiverc.HiveRCOutputFormat.Writer
 
writeRecord(Schema, Object, Encoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
Overriding to fetch the field value from the Tuple.
WriterIndexFooter() - Method in class org.apache.pig.piggybank.storage.IndexedStorage.IndexManager
Writes the index footer
writeSignedVarInt(int, DataOutput) - Static method in class org.apache.pig.data.utils.SedesHelper.Varint
 
writeSignedVarLong(long, DataOutput) - Static method in class org.apache.pig.data.utils.SedesHelper.Varint
Encodes a value using the variable-length encoding from Google Protocol Buffers.
writeUnion(Schema, Object, Encoder) - Method in class org.apache.pig.piggybank.storage.avro.PigAvroDatumWriter
Called to write union.
writeUnsignedVarInt(int, DataOutput) - Static method in class org.apache.pig.data.utils.SedesHelper.Varint
 
writeUnsignedVarLong(long, DataOutput) - Static method in class org.apache.pig.data.utils.SedesHelper.Varint
Encodes a value using the variable-length encoding from Google Protocol Buffers.

X

XMLLoader - Class in org.apache.pig.piggybank.storage
Parses an XML input file given a specified identifier of tags to be loaded.
XMLLoader(String) - Constructor for class org.apache.pig.piggybank.storage.XMLLoader
 
XMLLoader.XMLRecordReader - Class in org.apache.pig.piggybank.storage
Use this record reader to read XML tags out of a text file.
XMLMRPrinter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans
A visitor mechanism printing out the logical plan.
XMLMRPrinter(PrintStream, MROperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.XMLMRPrinter
 
XMLPhysicalPlanPrinter<P extends OperatorPlan<PhysicalOperator>> - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans
 
XMLPhysicalPlanPrinter(PhysicalPlan, Document, Element) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.XMLPhysicalPlanPrinter
 
XMLRecordReader(RecordReader<LongWritable, Text>) - Constructor for class org.apache.pig.piggybank.storage.XMLLoader.XMLRecordReader
 
XMLSparkPrinter - Class in org.apache.pig.backend.hadoop.executionengine.spark.plan
 
XMLSparkPrinter(PrintStream, SparkOperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.spark.plan.XMLSparkPrinter
 
XPath - Class in org.apache.pig.piggybank.evaluation.xml
XPath is a function that allows for text extraction from xml
XPath() - Constructor for class org.apache.pig.piggybank.evaluation.xml.XPath
 
XPathAll - Class in org.apache.pig.piggybank.evaluation.xml
XPathAll is a function that allows for Tuple extraction from xml
XPathAll() - Constructor for class org.apache.pig.piggybank.evaluation.xml.XPathAll
 
XPathAll.ARGUMENTS - Enum in org.apache.pig.piggybank.evaluation.xml
 

Y

YARN_DEFAULT_SITE - Static variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
YARN_SITE - Static variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
YearsBetween - Class in org.apache.pig.builtin
YearsBetween returns the number of years between two DateTime objects
YearsBetween() - Constructor for class org.apache.pig.builtin.YearsBetween
 

Z

zookeepers - Variable in class org.apache.pig.backend.hadoop.accumulo.AbstractAccumuloStorage
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

Copyright © 2007-2017 The Apache Software Foundation