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

A

accumulateStats() - Method in class org.apache.pig.tools.pigstats.PigStats
 
actionPerformed(ActionEvent) - Method in class org.apache.pig.tools.streams.StreamGenerator
 
activeScopes() - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
List scopes that are active in the back-end
activeScopes() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
activeScopes() - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
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(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.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(E) - Method in class org.apache.pig.impl.util.IdentityHashSet
 
addAlias(String, Schema.FieldSchema) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
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
Add contents of a bag to the bag.
addAll(Collection<Tuple>) - Method in class org.apache.pig.data.DefaultAbstractBag
Add contents of a container to the bag.
addAll(DataBag) - Method in class org.apache.pig.data.DistinctDataBag
 
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(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
addHandleSpec(StreamingCommand.Handle, StreamingCommand.HandleSpec) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Attach a StreamingCommand.HandleSpec to a given StreamingCommand.Handle
addInputPlan(PhysicalPlan, boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
addJar(String) - Method in class org.apache.pig.impl.PigContext
 
addJar(URL) - Method in class org.apache.pig.impl.PigContext
 
addOutput(LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.LOSplit
 
addPackage(POPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMultiQueryPackage
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, byte) - 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
Algebraic - Interface in org.apache.pig
An interface to declare that an EvalFunc's calculation can be decomposed into intitial, intermediate, and final steps.
alias - Variable in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Alias for this field.
allInputFromPredecessorConsumed - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
allOutputFromBinaryProcessed - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
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
 
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.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.pen.util.ExampleTuple
 
ARITY - Class in org.apache.pig.builtin
 
ARITY() - Constructor for class org.apache.pig.builtin.ARITY
 
asCollection(String) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
asCollection(String) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
asCollection(String) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
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
 
asContainer(String) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
asContainer(ContainerDescriptor) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
asContainer(String, String) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
asContainer(ContainerDescriptor, String) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
asContainer(ContainerDescriptor, ContainerDescriptor) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
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
 
asElement(String) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
asElement(ElementDescriptor) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
asElement(String, String) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
asElement(ContainerDescriptor, String) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
asElement(ContainerDescriptor, ElementDescriptor) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
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(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.POMultiQueryPackage
 
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.
attachInputToPlans(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
AugmentBaseDataVisitor - Class in org.apache.pig.pen
 
AugmentBaseDataVisitor(LogicalPlan, Map<LOLoad, DataBag>, Map<LogicalOperator, DataBag>) - Constructor for class org.apache.pig.pen.AugmentBaseDataVisitor
 
available() - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
available() - Method in class org.apache.pig.backend.local.datastorage.LocalSeekableInputStream
 
available() - Method in class org.apache.pig.impl.io.FileLocalizer.DataStorageInputStreamIterator
 
AVG - Class in org.apache.pig.builtin
Generates the average of the values of the first field of a tuple.
AVG() - Constructor for class org.apache.pig.builtin.AVG
 
AVG.Final - Class in org.apache.pig.builtin
 
AVG.Final() - Constructor for class org.apache.pig.builtin.AVG.Final
 
AVG.Initial - Class in org.apache.pig.builtin
 
AVG.Initial() - Constructor for class org.apache.pig.builtin.AVG.Initial
 
AVG.Intermediate - Class in org.apache.pig.builtin
 
AVG.Intermediate() - Constructor for class org.apache.pig.builtin.AVG.Intermediate
 

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 - Static variable in class org.apache.pig.data.DataType
 
bagFactory - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
BagFactory - Class in org.apache.pig.data
Factory for constructing different types of bags.
BagFactory() - Constructor for class org.apache.pig.data.BagFactory
 
bags - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
BagSize - Class in org.apache.pig.builtin
Generates the size of the first field of a tuple.
BagSize() - Constructor for class org.apache.pig.builtin.BagSize
 
BIGCHARARRAY - Static variable in class org.apache.pig.data.DataType
 
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
 
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
 
BinaryExpressionOperator - Class in org.apache.pig.impl.logicalLayer
This abstract class represents the logical Binary Expression Operator The binary operator has two operands and an operator.
BinaryExpressionOperator(LogicalPlan, OperatorKey, int) - Constructor for class org.apache.pig.impl.logicalLayer.BinaryExpressionOperator
 
BinaryExpressionOperator(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.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
 
BinaryStorage - Class in org.apache.pig.builtin
BinaryStorage is a simple, as-is, serializer/deserializer pair.
BinaryStorage() - Constructor for class org.apache.pig.builtin.BinaryStorage
Create a BinaryStorage with default buffer size for reading inputs.
BinaryStorage(int) - Constructor for class org.apache.pig.builtin.BinaryStorage
Create a BinaryStorage with the given buffer-size for reading inputs.
bindTo(String, BufferedPositionedInputStream, long, long) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
bindTo(String, BufferedPositionedInputStream, long, long) - Method in class org.apache.pig.builtin.BinaryStorage
 
bindTo(OutputStream) - Method in class org.apache.pig.builtin.BinaryStorage
 
bindTo(String, BufferedPositionedInputStream, long, long) - Method in class org.apache.pig.builtin.BinStorage
 
bindTo(OutputStream) - Method in class org.apache.pig.builtin.BinStorage
 
bindTo(OutputStream) - Method in class org.apache.pig.builtin.PigDump
 
bindTo(String, BufferedPositionedInputStream, long, long) - Method in class org.apache.pig.builtin.PigStorage
 
bindTo(OutputStream) - Method in class org.apache.pig.builtin.PigStorage
 
bindTo(String, BufferedPositionedInputStream, long, long) - Method in class org.apache.pig.builtin.TextLoader
 
bindTo(String, BufferedPositionedInputStream, long, long) - Method in class org.apache.pig.impl.builtin.RandomSampleLoader
 
bindTo(OutputStream) - Method in class org.apache.pig.impl.builtin.RandomSampleLoader
 
bindTo(OutputStream) - Method in class org.apache.pig.impl.streaming.DefaultInputHandler
 
bindTo(String, BufferedPositionedInputStream, long, long) - Method in class org.apache.pig.impl.streaming.DefaultOutputHandler
 
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.
bindTo(String, BufferedPositionedInputStream, long, long) - Method in interface org.apache.pig.LoadFunc
Specifies a portion of an InputStream to read tuples.
bindTo(OutputStream) - Method in interface org.apache.pig.StoreFunc
Specifies the OutputStream to write to.
BinStorage - Class in org.apache.pig.builtin
 
BinStorage() - Constructor for class org.apache.pig.builtin.BinStorage
Simple binary nested reader format
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.
BOOLEAN - Static variable in class org.apache.pig.data.DataType
 
breadthFirst() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
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
 
bufferSize - Variable in class org.apache.pig.builtin.BinaryStorage
 
BUG - Static variable in exception org.apache.pig.PigException
 
BYTE - Static variable in class org.apache.pig.data.DataType
 
BYTEARRAY - Static variable in class org.apache.pig.data.DataType
 
bytesToBag(byte[]) - Method in class org.apache.pig.builtin.BinStorage
 
bytesToBag(byte[]) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not support conversion to Bag
bytesToBag(byte[]) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToBag(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
bytesToBag(byte[]) - Method in interface org.apache.pig.LoadFunc
Cast data from bytes to bag value.
bytesToBigCharArray(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
bytesToBoolean(byte[]) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not support conversion to Boolean.
bytesToCharArray(byte[]) - Method in class org.apache.pig.builtin.BinStorage
 
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.LoadFunc
Cast data from bytes to chararray value.
bytesToDouble(byte[]) - Method in class org.apache.pig.builtin.BinStorage
 
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.LoadFunc
Cast data from bytes to double value.
bytesToFloat(byte[]) - Method in class org.apache.pig.builtin.BinStorage
 
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.LoadFunc
Cast data from bytes to float value.
bytesToInteger(byte[]) - Method in class org.apache.pig.builtin.BinStorage
 
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.LoadFunc
Cast data from bytes to integer value.
bytesToLong(byte[]) - Method in class org.apache.pig.builtin.BinStorage
 
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.LoadFunc
Cast data from bytes to long value.
bytesToMap(byte[]) - Method in class org.apache.pig.builtin.BinStorage
 
bytesToMap(byte[]) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not support conversion to Map
bytesToMap(byte[]) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToMap(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
bytesToMap(byte[]) - Method in interface org.apache.pig.LoadFunc
Cast data from bytes to map value.
bytesToTuple(byte[]) - Method in class org.apache.pig.builtin.BinStorage
 
bytesToTuple(byte[]) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not support conversion to Tuple
bytesToTuple(byte[]) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
bytesToTuple(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
bytesToTuple(byte[]) - Method in interface org.apache.pig.LoadFunc
Cast data from bytes to tuple value.

C

calculateProgress(JobControl, JobClient) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.Launcher
Compute the progress of the current job submitted through the JobControl object jc to the JobClient jobClient
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.
capacity() - Method in class org.apache.pig.PigServer
Returns the unused byte capacity of an HDFS filesystem.
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
castLookup - Static variable in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
chainOfProjects(LogicalPlan) - Static method in class org.apache.pig.impl.logicalLayer.LogicalPlan
A utility method to check if a plan contains a chain of projection operators
changes() - Method in class org.apache.pig.impl.plan.ProjectionMap
 
CHARARRAY - Static variable in class org.apache.pig.data.DataType
 
check(List<LogicalOperator>) - Method in class org.apache.pig.impl.logicalLayer.optimizer.ImplicitSplitInserter
 
check(List<LogicalOperator>) - Method in class org.apache.pig.impl.logicalLayer.optimizer.OpLimitOptimizer
 
check(List<LogicalOperator>) - Method in class org.apache.pig.impl.logicalLayer.optimizer.StreamOptimizer
 
check(List<LogicalOperator>) - Method in class org.apache.pig.impl.logicalLayer.optimizer.TypeCastInserter
 
check(List<O>) - Method in class org.apache.pig.impl.plan.optimizer.Transformer
check if the transform should be done.
checkLeafIsStore(PhysicalPlan, PigContext) - Static method in class org.apache.pig.backend.executionengine.util.ExecTools
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
 
classloader - Static variable in class org.apache.pig.impl.logicalLayer.LogicalPlanBuilder
 
cleanUp() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReducePOStoreImpl
 
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() - Method in class org.apache.pig.backend.local.executionengine.LocalPOStoreImpl
 
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.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.IdentityHashSet
 
clear() - Method in class org.apache.pig.impl.util.MultiMap
 
clearDeleteOnFail() - Static method in class org.apache.pig.impl.io.FileLocalizer
 
clearDone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POUnion
 
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 deep 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.PODistinct
 
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.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.POLocalRearrangeForIllustrate
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.POPackageLite
Make a deep copy of this operator.
clone() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
clone() - Method in class org.apache.pig.FuncSpec
 
clone() - Method in class org.apache.pig.impl.logicalLayer.BinaryExpressionOperator
 
clone() - Method in class org.apache.pig.impl.logicalLayer.ExpressionOperator
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOBinCond
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOCast
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOConst
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LODistinct
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOFilter
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOGenerate
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LogicalPlan
Do not use the clone method directly.
clone() - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOMapLookup
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOSplit
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOUnion
 
clone() - Method in class org.apache.pig.impl.logicalLayer.LOUserFunc
 
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.logicalLayer.UnaryExpressionOperator
 
clone() - Method in class org.apache.pig.impl.plan.Operator
 
clone() - Method in class org.apache.pig.impl.plan.optimizer.RuleOperator
 
clone() - Method in class org.apache.pig.impl.streaming.StreamingCommand
 
clone() - Method in class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
 
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(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
 
clonePlan(String) - Method in class org.apache.pig.PigServer
 
close() - Method in interface org.apache.pig.backend.datastorage.DataStorage
Clean-up and releasing of resources.
close() - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Clean-up and releasing of resources.
close() - Method in class org.apache.pig.backend.executionengine.PigSlice
 
close() - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
close() - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
close() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
close() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
Will be called once all the intermediate keys and values are processed.
close() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
Will be called when all the tuples in the input are done.
close() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
Will be called once all the intermediate keys and values are processed.
close(Reporter) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat.PigRecordWriter
 
close() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
close() - Method in class org.apache.pig.backend.hadoop.streaming.HadoopExecutableManager
 
close() - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
close() - Method in class org.apache.pig.backend.local.datastorage.LocalSeekableInputStream
 
close() - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
close() - Method in class org.apache.pig.impl.io.BufferedPositionedInputStream
 
close() - Method in class org.apache.pig.impl.io.FileLocalizer.DataStorageInputStreamIterator
 
close(Process) - Method in class org.apache.pig.impl.streaming.DefaultInputHandler
 
close() - Method in class org.apache.pig.impl.streaming.DefaultOutputHandler
 
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() - Method in class org.apache.pig.impl.streaming.FileOutputHandler
 
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 interface org.apache.pig.Slice
Closes any streams this Slice has opened as part of its work.
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(OutputCollector<PigNullableWritable, Writable>, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
 
collect(OutputCollector<PigNullableWritable, Writable>, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapOnly.Map
 
collect(OutputCollector<PigNullableWritable, Writable>, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Map
 
collect(OutputCollector<PigNullableWritable, Writable>, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.MapWithComparator
 
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
 
columns - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
combinable() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
combine(DataBag) - Static method in class org.apache.pig.builtin.AVG
 
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
 
combinePlan - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
CombinerOptimizer - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Optimize map reduce plans to use the combiner where possible.
CombinerOptimizer(MROperPlan, String) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.CombinerOptimizer
 
CombinerOptimizer(MROperPlan, String, CompilationMessageCollector) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.CombinerOptimizer
 
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
 
CommonNodeFinder - Class in org.apache.pig.impl.plan.optimizer
 
CommonNodeFinder(RulePlan) - Constructor for class org.apache.pig.impl.plan.optimizer.CommonNodeFinder
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.pig.backend.hadoop.DoubleWritable.Comparator
 
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.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.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.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.PigTupleRawComparator
Compare two NullableTuples as raw bytes.
compare(Object, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleRawComparator
 
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
 
compare(Tuple, Tuple) - Method in class org.apache.pig.ComparisonFunc
This callback method must be implemented by all subclasses.
compare(Object, Object) - Static method in class org.apache.pig.data.DataType
/** Compare two objects to each other.
compareTo(ElementDescriptor) - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
compareTo(Object) - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
compareTo(ElementDescriptor) - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
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.NonSpillableDataBag
 
compareTo(Object) - Method in class org.apache.pig.data.ReadOnceBag
 
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.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.pen.util.ExampleTuple
 
ComparisonFunc - Class in org.apache.pig
 
ComparisonFunc() - Constructor for class org.apache.pig.ComparisonFunc
 
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.Message(String, CompilationMessageCollector.MessageType) - Constructor for class org.apache.pig.impl.plan.CompilationMessageCollector.Message
 
CompilationMessageCollector.Message(String, CompilationMessageCollector.MessageType, Enum) - Constructor for class org.apache.pig.impl.plan.CompilationMessageCollector.Message
 
CompilationMessageCollector.MessageType - Enum in org.apache.pig.impl.plan
 
compile(LogicalPlan, Properties) - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Compiles a logical plan into a physical plan, given a set of configuration properties that apply at the plan-level.
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() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
The front-end method that the user calls to compile the plan.
compile(LogicalPlan, Properties) - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
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
 
completionNotification(Object) - Method in class org.apache.pig.backend.local.executionengine.LocalJob
 
computeTimeSpent(TaskReport[]) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.Launcher
 
CONCAT - Class in org.apache.pig.builtin
Generates the concatenation of the first two fields of a tuple.
CONCAT() - Constructor for class org.apache.pig.builtin.CONCAT
 
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(JobConf) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.DistinctCombiner.Combine
Configures the reporter
configure(JobConf) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
configure(JobConf) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
Configures the Reduce plan, the POPackage operator and the reporter thread
configure(JobConf) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
configure(JobConf) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
Configures the mapper with the map plan and the reproter thread
configure(JobConf) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
Configures the Reduce plan, the POPackage operator and the reporter thread
configure(JobConf) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.ReduceWithComparator
Configures the Reduce plan, the POPackage operator and the reporter thread
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(Properties) - Static method in class org.apache.pig.impl.util.SpillableMemoryManager
 
connect(PhysicalOperator, PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
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.
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
 
ConstantSize - Class in org.apache.pig.builtin
Generates the size of the first field of a tuple.
ConstantSize() - Constructor for class org.apache.pig.builtin.ConstantSize
 
constructLROutput(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.POLocalRearrangeForIllustrate
 
constructLROutput(List<Result>, Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
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
 
containsAll(Collection<?>) - Method in class org.apache.pig.impl.util.IdentityHashSet
 
containsKey(K) - Method in class org.apache.pig.impl.util.MultiMap
 
containsValue(V) - Method in class org.apache.pig.impl.util.MultiMap
 
contentLength - Variable in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
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(ElementDescriptor, Properties, boolean) - Method in class org.apache.pig.backend.local.datastorage.LocalDir
 
copy(ContainerDescriptor, Properties, boolean) - Method in class org.apache.pig.backend.local.datastorage.LocalDir
 
copy(ElementDescriptor, Properties, boolean) - Method in class org.apache.pig.backend.local.datastorage.LocalFile
 
copy(ElementDescriptor, Properties, boolean) - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
copy(ElementDescriptor, boolean) - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
copy(String, String, boolean) - Method in class org.apache.pig.impl.PigContext
 
count(Tuple) - Static method in class org.apache.pig.builtin.AVG
 
COUNT - Class in org.apache.pig.builtin
Generates the count of the values of the first field of a tuple.
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.Final() - Constructor for class org.apache.pig.builtin.COUNT.Final
 
COUNT.Initial - Class in org.apache.pig.builtin
 
COUNT.Initial() - Constructor for class org.apache.pig.builtin.COUNT.Initial
 
COUNT.Intermediate - Class in org.apache.pig.builtin
 
COUNT.Intermediate() - Constructor for class org.apache.pig.builtin.COUNT.Intermediate
 
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
 
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(Properties) - Method in class org.apache.pig.backend.local.datastorage.LocalDir
 
create(Properties) - Method in class org.apache.pig.backend.local.datastorage.LocalFile
 
create(Properties) - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
create() - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
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
 
createCl(String) - Method in class org.apache.pig.impl.PigContext
Creates a Classloader based on the passed jarFile and any extra jar files.
createExecutableManager() - Method in class org.apache.pig.impl.PigContext
Create a new ExecutableManager depending on the ExecType.
createInputHandler(StreamingCommand) - Static method in class org.apache.pig.impl.streaming.HandlerFactory
Create an InputHandler for the given input specification of the StreamingCommand.
createJar(OutputStream, List<String>, PigContext) - Static method in class org.apache.pig.impl.util.JarManager
Create a jarfile in a temporary path, that is a merge of all the jarfiles containing the functions and the core pig classes.
createOutputHandler(StreamingCommand) - Static method in class org.apache.pig.impl.streaming.HandlerFactory
Create an OutputHandler for the given output specification of the StreamingCommand.
createStoreFunc(FileSpec, Schema) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReducePOStoreImpl
 
createStoreFunc(FileSpec, Schema) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStoreImpl
Set up the storer
createStoreFunc(FileSpec, Schema) - Method in class org.apache.pig.backend.local.executionengine.LocalPOStoreImpl
 
CreateTuple(Object[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
curMark - Variable in class org.apache.pig.backend.local.datastorage.LocalSeekableInputStream
 
currentPlan - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
currentPlans - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 

D

data - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
DataBag - Interface in org.apache.pig.data
A collection of Tuples.
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.
DataReaderWriter - Class in org.apache.pig.data
A class to handle reading and writing of intermediate results of data types.
DataReaderWriter() - Constructor for class org.apache.pig.data.DataReaderWriter
 
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.
DataType - Class in org.apache.pig.data
A class of static final values used to encode data type and a number of static helper funcitons for manipulating data objects.
DataType() - Constructor for class org.apache.pig.data.DataType
 
debug - Variable in class org.apache.pig.impl.PigContext
 
debugOff() - Method in class org.apache.pig.PigServer
 
debugOn() - Method in class org.apache.pig.PigServer
 
decodeBytes(String) - Static method in class org.apache.pig.impl.util.ObjectSerializer
 
DEFAULT_CHUNK_SIZE - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POJoinPackage
 
DEFAULT_PARALLELISM - Static variable in class org.apache.pig.impl.builtin.GFCross
 
DEFAULT_REPLICATION_FACTOR_KEY - Static variable in interface org.apache.pig.backend.datastorage.DataStorage
 
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.BagDelimiterTuple() - Constructor for class org.apache.pig.data.DefaultAbstractBag.BagDelimiterTuple
 
DefaultAbstractBag.EndBag - Class in org.apache.pig.data
 
DefaultAbstractBag.EndBag() - Constructor for class org.apache.pig.data.DefaultAbstractBag.EndBag
 
DefaultAbstractBag.StartBag - Class in org.apache.pig.data
 
DefaultAbstractBag.StartBag() - Constructor for class org.apache.pig.data.DefaultAbstractBag.StartBag
 
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.
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
 
defaultNumSamples - Static variable in class org.apache.pig.impl.builtin.RandomSampleLoader
 
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
 
DefaultTuple - Class in org.apache.pig.data
A default implementation of Tuple.
DefaultTuple() - Constructor for class org.apache.pig.data.DefaultTuple
Default constructor.
DefaultTupleFactory - Class in org.apache.pig.data
Default implementation of TupleFactory.
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() - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
delete(String, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
deleteFile(String) - Method in class org.apache.pig.PigServer
 
deleteTempFiles() - Static method in class org.apache.pig.impl.io.FileLocalizer
 
DependencyOrderLimitedWalker<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.pen.util
 
DependencyOrderLimitedWalker(O, P) - Constructor for class org.apache.pig.pen.util.DependencyOrderLimitedWalker
 
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
 
DependencyOrderWalkerWOSeenChk<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.
DependencyOrderWalkerWOSeenChk(P) - Constructor for class org.apache.pig.impl.plan.DependencyOrderWalkerWOSeenChk
 
depthFirst() - Method in class org.apache.pig.impl.plan.optimizer.RulePlanPrinter
 
depthFirst() - Method in class org.apache.pig.impl.plan.PlanPrinter
 
depthFirstLP() - Method in class org.apache.pig.impl.logicalLayer.LOPrinter
 
depthFirstPP() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
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
 
DerivedDataVisitor - Class in org.apache.pig.pen
 
DerivedDataVisitor(LogicalPlan, PigContext, Map<LOLoad, DataBag>, Map<LogicalOperator, PhysicalOperator>, PhysicalPlan) - Constructor for class org.apache.pig.pen.DerivedDataVisitor
 
DerivedDataVisitor(LogicalOperator, PigContext, Map<LOLoad, DataBag>, Map<LogicalOperator, PhysicalOperator>, PhysicalPlan) - Constructor for class org.apache.pig.pen.DerivedDataVisitor
 
deserialize(String) - Static method in class org.apache.pig.impl.util.ObjectSerializer
 
deserializer - Variable in class org.apache.pig.impl.streaming.OutputHandler
 
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.relationalOperators.POMultiQueryPackage
 
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
 
determineErrorSource(int) - Static method in exception org.apache.pig.PigException
A static method to determine the error source given the error code
determineFieldSchema(Object) - Static method in class org.apache.pig.data.DataType
Determine the field schema of an object
determineSchema(String, ExecType, DataStorage) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
determineSchema(String, ExecType, DataStorage) - Method in class org.apache.pig.builtin.BinaryStorage
 
determineSchema(String, ExecType, DataStorage) - Method in class org.apache.pig.builtin.BinStorage
 
determineSchema(String, ExecType, DataStorage) - Method in class org.apache.pig.builtin.PigStorage
 
determineSchema(String, ExecType, DataStorage) - Method in class org.apache.pig.builtin.TextLoader
TextLoader does not provide a schema.
determineSchema(String, ExecType, DataStorage) - Method in interface org.apache.pig.LoadFunc
Find the schema from the loader.
DIFF - Class in org.apache.pig.builtin
DIFF compares the fields of a tuple with arity 2.
DIFF() - Constructor for class org.apache.pig.builtin.DIFF
 
discardBatch() - Method in class org.apache.pig.PigServer
Discards a batch of Pig commands.
disconnect(E, E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Remove an edge from between two nodes.
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
 
DiscreteProbabilitySampleGenerator(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
 
distinct - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
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.Final() - Constructor for class org.apache.pig.builtin.Distinct.Final
 
Distinct.Initial - Class in org.apache.pig.builtin
 
Distinct.Initial() - Constructor for class org.apache.pig.builtin.Distinct.Initial
 
Distinct.Intermediate - Class in org.apache.pig.builtin
 
Distinct.Intermediate() - Constructor for class org.apache.pig.builtin.Distinct.Intermediate
 
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
 
DistinctCombiner.Combine() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.DistinctCombiner.Combine
 
DistinctDataBag - Class in org.apache.pig.data
An unordered collection of Tuples with no multiples.
DistinctDataBag() - Constructor for class org.apache.pig.data.DistinctDataBag
 
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
 
doAllPredecessors(O, Set<O>, Collection<O>) - Method in class org.apache.pig.impl.plan.DependencyOrderWalker
 
doAllSuccessors(O, Set<O>, Collection<O>) - Method in class org.apache.pig.impl.plan.ReverseDependencyOrderWalker
 
DotLOPrinter - Class in org.apache.pig.impl.logicalLayer
This class can print a logical plan in the DOT format.
DotLOPrinter(LogicalPlan, PrintStream) - Constructor for class org.apache.pig.impl.logicalLayer.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.InnerOperator(PhysicalPlan, String) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter.InnerOperator
 
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.
DotMRPrinter.InnerPlan(PhysicalPlan, PhysicalPlan, PhysicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter.InnerPlan
 
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
 
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
 
DOUBLE - Static variable in class org.apache.pig.data.DataType
 
DoubleAvg - Class in org.apache.pig.builtin
Generates the average of the values of the first field of a tuple.
DoubleAvg() - Constructor for class org.apache.pig.builtin.DoubleAvg
 
DoubleAvg.Final - Class in org.apache.pig.builtin
 
DoubleAvg.Final() - Constructor for class org.apache.pig.builtin.DoubleAvg.Final
 
DoubleAvg.Initial - Class in org.apache.pig.builtin
 
DoubleAvg.Initial() - Constructor for class org.apache.pig.builtin.DoubleAvg.Initial
 
DoubleAvg.Intermediate - Class in org.apache.pig.builtin
 
DoubleAvg.Intermediate() - Constructor for class org.apache.pig.builtin.DoubleAvg.Intermediate
 
DoubleMax - Class in org.apache.pig.builtin
Generates the max of the values of the first field of a tuple.
DoubleMax() - Constructor for class org.apache.pig.builtin.DoubleMax
 
DoubleMax.Final - Class in org.apache.pig.builtin
 
DoubleMax.Final() - Constructor for class org.apache.pig.builtin.DoubleMax.Final
 
DoubleMax.Initial - Class in org.apache.pig.builtin
 
DoubleMax.Initial() - Constructor for class org.apache.pig.builtin.DoubleMax.Initial
 
DoubleMax.Intermediate - Class in org.apache.pig.builtin
 
DoubleMax.Intermediate() - Constructor for class org.apache.pig.builtin.DoubleMax.Intermediate
 
DoubleMin - Class in org.apache.pig.builtin
Generates the min of the Double values in the first field of a tuple.
DoubleMin() - Constructor for class org.apache.pig.builtin.DoubleMin
 
DoubleMin.Final - Class in org.apache.pig.builtin
 
DoubleMin.Final() - Constructor for class org.apache.pig.builtin.DoubleMin.Final
 
DoubleMin.Initial - Class in org.apache.pig.builtin
 
DoubleMin.Initial() - Constructor for class org.apache.pig.builtin.DoubleMin.Initial
 
DoubleMin.Intermediate - Class in org.apache.pig.builtin
 
DoubleMin.Intermediate() - Constructor for class org.apache.pig.builtin.DoubleMin.Intermediate
 
DoubleSum - Class in org.apache.pig.builtin
Generates the sum of the values of the first field of a tuple.
DoubleSum() - Constructor for class org.apache.pig.builtin.DoubleSum
 
DoubleSum.Final - Class in org.apache.pig.builtin
 
DoubleSum.Final() - Constructor for class org.apache.pig.builtin.DoubleSum.Final
 
DoubleSum.Initial - Class in org.apache.pig.builtin
 
DoubleSum.Initial() - Constructor for class org.apache.pig.builtin.DoubleSum.Initial
 
DoubleSum.Intermediate - Class in org.apache.pig.builtin
 
DoubleSum.Intermediate() - Constructor for class org.apache.pig.builtin.DoubleSum.Intermediate
 
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.
DoubleWritable.Comparator() - Constructor for class org.apache.pig.backend.hadoop.DoubleWritable.Comparator
 
ds - Variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
ds - Variable in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
dummyBag - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
dummyBool - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
dummyDBA - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
dummyDouble - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
dummyFloat - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
dummyInt - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
dummyLong - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
dummyMap - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
dummyString - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
dummyTuple - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
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.
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.
dumpInvisibleOperators(E) - Method in class org.apache.pig.impl.plan.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.
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.
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.
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
dumpSchema(String) - Method in class org.apache.pig.PigServer
 
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
 
duplicate() - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 

E

ElementDescriptor - Interface in org.apache.pig.backend.datastorage
DataStorageElementDescriptor provides methods necessary to manage an element in a DataStorage.
encodeBytes(byte[]) - Static method in class org.apache.pig.impl.util.ObjectSerializer
 
end - Variable in class org.apache.pig.builtin.BinaryStorage
 
end - Variable in class org.apache.pig.builtin.BinStorage
 
endBag - Static variable in class org.apache.pig.data.DefaultAbstractBag
 
endOfAllInput - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
EndOfOpts - Static variable in class org.apache.pig.tools.cmdline.CmdLineParser
 
equalByteArrays(byte[], byte[]) - Static method in class org.apache.pig.data.DataType
 
equals(Object) - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
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.physicalLayer.plans.PhysicalPlan
 
equals(Object) - Method in class org.apache.pig.builtin.BinaryStorage
 
equals(Object) - Method in class org.apache.pig.builtin.BinStorage
 
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.DataByteArray
 
equals(Object) - Method in class org.apache.pig.data.DefaultAbstractBag
 
equals(Object) - Method in class org.apache.pig.data.DefaultTuple
 
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.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
 
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
 
ERROR - Static variable in class org.apache.pig.data.DataType
 
ERROR - Static variable in exception org.apache.pig.PigException
 
errorCode - Variable in exception org.apache.pig.PigException
 
errorInMap - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
 
errorInReduce - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
 
errorSource - Variable in exception org.apache.pig.PigException
 
EvalFunc<T> - Class in org.apache.pig
The class is used to implement functions to be applied to a dataset.
EvalFunc() - Constructor for class org.apache.pig.EvalFunc
 
evaluateIsolatedOperator(LOCogroup, List<DataBag>) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
evaluateIsolatedOperator(LOCogroup) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
ExampleGenerator - Class in org.apache.pig.pen
 
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(Tuple) - Constructor for class org.apache.pig.pen.util.ExampleTuple
 
exec() - Method in class org.apache.pig.backend.hadoop.streaming.HadoopExecutableManager
 
exec(Tuple) - Method in class org.apache.pig.builtin.ARITY
 
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.CONCAT
 
exec(Tuple) - Method in class org.apache.pig.builtin.ConstantSize
 
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.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.DoubleMax
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleMax.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleMax.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleMax.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleMin
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleMin.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleMin.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleMin.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleSum
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleSum.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleSum.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.DoubleSum.Intermediate
 
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.FloatMax
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatMax.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatMax.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatMax.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatMin
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatMin.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatMin.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatMin.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatSum
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatSum.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatSum.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.FloatSum.Intermediate
 
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.IntMax
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntMax.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntMax.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntMax.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntMin
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntMin.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntMin.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntMin.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntSum
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntSum.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntSum.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.IntSum.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.IsEmpty
 
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.LongMax
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongMax.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongMax.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongMax.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongMin
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongMin.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongMin.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongMin.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongSum
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongSum.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongSum.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.LongSum.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.MapSize
 
exec(Tuple) - Method in class org.apache.pig.builtin.MAX
 
exec(Tuple) - Method in class org.apache.pig.builtin.MAX.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.MAX.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.MAX.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.MIN
 
exec(Tuple) - Method in class org.apache.pig.builtin.MIN.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.MIN.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.MIN.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.RANDOM
 
exec(Tuple) - Method in class org.apache.pig.builtin.SIZE
 
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.SUM
 
exec(Tuple) - Method in class org.apache.pig.builtin.SUM.Final
 
exec(Tuple) - Method in class org.apache.pig.builtin.SUM.Initial
 
exec(Tuple) - Method in class org.apache.pig.builtin.SUM.Intermediate
 
exec(Tuple) - Method in class org.apache.pig.builtin.TOKENIZE
 
exec(Tuple) - Method in class org.apache.pig.builtin.TupleSize
 
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.GFAny
 
exec(Tuple) - Method in class org.apache.pig.impl.builtin.GFCross
 
exec(Tuple) - Method in class org.apache.pig.impl.builtin.GFReplicate
 
exec() - Method in class org.apache.pig.impl.streaming.ExecutableManager
Start execution of the external process.
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
 
ExecPhysicalOperator - Interface in org.apache.pig.backend.executionengine
 
ExecPhysicalPlan - Interface in org.apache.pig.backend.executionengine
 
ExecScopedLogicalOperator - Interface in org.apache.pig.backend.executionengine
 
ExecTools - Class in org.apache.pig.backend.executionengine.util
A collection of static methods for use by the executionengine implementations.
ExecTools() - Constructor for class org.apache.pig.backend.executionengine.util.ExecTools
 
ExecType - Enum in org.apache.pig
The type of query execution
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(PhysicalPlan, String) - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Execute the physical plan in blocking mode.
execute(PhysicalPlan, String) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
execute(PhysicalPlan, String) - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
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.
ExecutionEngine - Interface in org.apache.pig.backend.executionengine
TODO: provide a manner to generate/collect logging information for DBG purposes TODO: add keys for properties/statistics
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
 
exists() - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
existsFile(String) - Method in class org.apache.pig.PigServer
 
exitCode - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
explain(OutputStream) - Method in interface org.apache.pig.backend.executionengine.ExecPhysicalPlan
To provide an "explanation" about how the physical plan has been constructed
explain(PhysicalPlan, PrintStream, String, boolean) - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Explain executor specific information.
explain(PhysicalPlan, PrintStream, String, boolean) - 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.mapReduceLayer.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, PrintStream, String, boolean) - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
explain(PhysicalPlan, PigContext, PrintStream, String, boolean) - Method in class org.apache.pig.backend.local.executionengine.LocalPigLauncher
 
explain(OutputStream, PrintStream) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlan
 
explain(PrintStream, String, boolean) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlan
 
explain(OutputStream, PrintStream) - Method in class org.apache.pig.impl.plan.OperatorPlan
 
explain(OutputStream, PrintStream) - Method in class org.apache.pig.impl.plan.optimizer.RulePlan
 
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, PrintStream) - Method in class org.apache.pig.PigServer
Provide information on how a pig query will be executed.
explainCurrentBatch() - Method in class org.apache.pig.tools.grunt.GruntParser
 
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
 
ExpressionOperator - Class in org.apache.pig.impl.logicalLayer
 
ExpressionOperator(LogicalPlan, OperatorKey, int) - Constructor for class org.apache.pig.impl.logicalLayer.ExpressionOperator
 
ExpressionOperator(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.ExpressionOperator
 
extraJars - Variable in class org.apache.pig.impl.PigContext
 

F

failedStores - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.Launcher
 
falseRef - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryComparisonOperator
 
fieldsToRead(Schema) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
fieldsToRead(Schema) - Method in class org.apache.pig.builtin.BinaryStorage
 
fieldsToRead(Schema) - Method in class org.apache.pig.builtin.BinStorage
 
fieldsToRead(Schema) - Method in class org.apache.pig.builtin.PigStorage
 
fieldsToRead(Schema) - Method in class org.apache.pig.builtin.TextLoader
TextLoader doesn't make use of this.
fieldsToRead(Schema) - Method in interface org.apache.pig.LoadFunc
Indicate to the loader fields that will be needed.
file - Variable in class org.apache.pig.backend.local.datastorage.LocalSeekableInputStream
 
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
 
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.DataStorageInputStreamIterator(ElementDescriptor[]) - Constructor for class org.apache.pig.impl.io.FileLocalizer.DataStorageInputStreamIterator
 
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).
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
 
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
 
finalize() - Method in class org.apache.pig.data.DefaultAbstractBag
Need to override finalize to clean out the mSpillFiles array.
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.
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
 
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.
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.BinaryStorage
 
finish() - Method in class org.apache.pig.builtin.BinStorage
 
finish() - Method in class org.apache.pig.builtin.PigDump
 
finish() - Method in class org.apache.pig.builtin.PigStorage
 
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 interface org.apache.pig.StoreFunc
Do any kind of post processing because the last tuple has been stored.
first - Variable in class org.apache.pig.impl.util.Pair
 
fixUpContainedPlans(LogicalOperator, LogicalOperator, LogicalOperator, Map<Integer, Integer>) - Method in class org.apache.pig.impl.logicalLayer.optimizer.LogicalTransformer
Once a node has been inserted, inner plans associated with other nodes may have references to the node that has been replaced or moved.
FLOAT - Static variable in class org.apache.pig.data.DataType
 
FloatAvg - Class in org.apache.pig.builtin
Generates the average of the values of the first field of a tuple.
FloatAvg() - Constructor for class org.apache.pig.builtin.FloatAvg
 
FloatAvg.Final - Class in org.apache.pig.builtin
 
FloatAvg.Final() - Constructor for class org.apache.pig.builtin.FloatAvg.Final
 
FloatAvg.Initial - Class in org.apache.pig.builtin
 
FloatAvg.Initial() - Constructor for class org.apache.pig.builtin.FloatAvg.Initial
 
FloatAvg.Intermediate - Class in org.apache.pig.builtin
 
FloatAvg.Intermediate() - Constructor for class org.apache.pig.builtin.FloatAvg.Intermediate
 
FloatMax - Class in org.apache.pig.builtin
Generates the max of the values of the first field of a tuple.
FloatMax() - Constructor for class org.apache.pig.builtin.FloatMax
 
FloatMax.Final - Class in org.apache.pig.builtin
 
FloatMax.Final() - Constructor for class org.apache.pig.builtin.FloatMax.Final
 
FloatMax.Initial - Class in org.apache.pig.builtin
 
FloatMax.Initial() - Constructor for class org.apache.pig.builtin.FloatMax.Initial
 
FloatMax.Intermediate - Class in org.apache.pig.builtin
 
FloatMax.Intermediate() - Constructor for class org.apache.pig.builtin.FloatMax.Intermediate
 
FloatMin - Class in org.apache.pig.builtin
Generates the min of the Float values in the first field of a tuple.
FloatMin() - Constructor for class org.apache.pig.builtin.FloatMin
 
FloatMin.Final - Class in org.apache.pig.builtin
 
FloatMin.Final() - Constructor for class org.apache.pig.builtin.FloatMin.Final
 
FloatMin.Initial - Class in org.apache.pig.builtin
 
FloatMin.Initial() - Constructor for class org.apache.pig.builtin.FloatMin.Initial
 
FloatMin.Intermediate - Class in org.apache.pig.builtin
 
FloatMin.Intermediate() - Constructor for class org.apache.pig.builtin.FloatMin.Intermediate
 
FloatSum - Class in org.apache.pig.builtin
Generates the sum of the Float values in the first field of a tuple.
FloatSum() - Constructor for class org.apache.pig.builtin.FloatSum
 
FloatSum.Final - Class in org.apache.pig.builtin
 
FloatSum.Final() - Constructor for class org.apache.pig.builtin.FloatSum.Final
 
FloatSum.Initial - Class in org.apache.pig.builtin
 
FloatSum.Initial() - Constructor for class org.apache.pig.builtin.FloatSum.Initial
 
FloatSum.Intermediate - Class in org.apache.pig.builtin
 
FloatSum.Intermediate() - Constructor for class org.apache.pig.builtin.FloatSum.Intermediate
 
forceSchema(Schema) - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Directly force the schema without reconcilation Please use with great care
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) - 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, 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.
fs - Variable in class org.apache.pig.backend.hadoop.datastorage.HPath
 
fs - Variable in class org.apache.pig.backend.local.datastorage.LocalPath
 
fullPath(String, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
FuncSpec - Class in org.apache.pig
Class to represent a UDF specification - essentially encapsulates the class name and the arguments to the constructor
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
 
FunctionalLogicalOptimizer - Class in org.apache.pig.pen.util
 
FunctionalLogicalOptimizer(LogicalPlan) - Constructor for class org.apache.pig.pen.util.FunctionalLogicalOptimizer
 
FunctionInstantiator - Interface in org.apache.pig.impl
 

G

genAllTypes() - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.operatorHelper
 
genAllTypes() - Static method in class org.apache.pig.data.DataType
 
generateNestedSchema(byte, byte...) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
genNameToTypeMap() - Static method in class org.apache.pig.data.DataType
 
genOpKey(String) - Static method in class org.apache.pig.impl.plan.OperatorKey
Utility function for creating operator keys.
genSubstitutedFile(BufferedReader, Writer, String[], String[]) - Method in class org.apache.pig.tools.parameters.ParameterSubstitutionPreprocessor
This is the main API that takes script template and produces pig script
genTypeToNameMap() - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.operatorHelper
 
genTypeToNameMap() - Static method in class org.apache.pig.data.DataType
 
get() - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
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.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.impl.plan.CompilationMessageCollector
 
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
 
getActiveContainer() - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
getActiveContainer() - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
getActiveContainer() - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
getActiveSplit() - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
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 class org.apache.pig.impl.logicalLayer.LogicalOperator
 
getAliases() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
getAliases() - Method in class org.apache.pig.PigServer
 
getAliasKeySet() - Method in class org.apache.pig.PigServer
 
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.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.pen.util.ExampleTuple
 
getAmendKey() - Method in class org.apache.pig.data.AmendableTuple
 
getArgStringFromSpec(String) - Static method in class org.apache.pig.FuncSpec
 
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.MAX
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.MIN
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.SIZE
 
getArgToFuncMapping() - Method in class org.apache.pig.builtin.SUM
 
getArgToFuncMapping() - Method in class org.apache.pig.EvalFunc
 
getArguments() - Method in class org.apache.pig.impl.logicalLayer.LOUserFunc
 
getAscendingCols() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
getAtomicGroupByType() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
This can be used to get the merged type of output group col only when the group col is of atomic type TODO: This doesn't work with group by complex type
getAtomicGroupByType(LOCogroup) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
This can be used to get the merged type of output group col only when the group col is of atomic type TODO: This doesn't work with group by complex type
getAtomicJoinColType() - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
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(LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.DotLOPrinter
 
getAttributes(E) - Method in class org.apache.pig.impl.plan.DotPlanDumper
Used to generate the the attributes of a node
getBaseIndex() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Returns the base index of this demux
getBaseIndex() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMultiQueryPackage
Returns the base index of this operator
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
 
getBytesWritten() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getCacheSpecs() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get the list of files which need to be cached on the execute nodes.
getCanonicalMap() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
 
getChanges() - Method in class org.apache.pig.impl.plan.ProjectionMap
 
getClassForAlias(String) - Method in class org.apache.pig.impl.PigContext
 
getClassName() - Method in class org.apache.pig.FuncSpec
 
getClassNameFromSpec(String) - Static method in class org.apache.pig.FuncSpec
 
getClonedPlan() - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
getClonedPlan() - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloner
 
getCol() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
getColumn() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getColumns() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
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.
getCommonNodes() - Method in class org.apache.pig.impl.plan.optimizer.CommonNodeFinder
 
getComparator() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getComparisonPlan() - Method in class org.apache.pig.impl.logicalLayer.LOFilter
 
getCompleteness(LogicalOperator, Map<LogicalOperator, DataBag>, Map<LogicalOperator, Collection<IdentityHashSet<Tuple>>>, boolean) - Static method in class org.apache.pig.pen.util.MetricEvaluation
 
getConciseness(LogicalOperator, Map<LogicalOperator, DataBag>, Map<LogicalOperator, Collection<IdentityHashSet<Tuple>>>, boolean) - Static method in class org.apache.pig.pen.util.MetricEvaluation
 
getCond() - Method in class org.apache.pig.impl.logicalLayer.LOBinCond
 
getConditionPlan() - Method in class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBytesRawComparator
 
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.PigTextRawComparator
 
getConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleRawComparator
 
getConf() - Method in class org.apache.pig.impl.PigContext
Deprecated. use PigContext.getProperties() instead
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.ExecPhysicalPlan
A job may have properties, like a priority, degree of parallelism...
getConfiguration() - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Provides configuration information about the execution engine itself.
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.local.datastorage.LocalDataStorage
 
getConfiguration() - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
getConfiguration() - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
getContiguration() - Method in interface org.apache.pig.backend.executionengine.ExecJob
Get configuration information
getContiguration() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getContiguration() - Method in class org.apache.pig.backend.local.executionengine.LocalJob
 
getCount() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.counters.POCounter
 
getCount() - Method in class org.apache.pig.impl.plan.optimizer.CommonNodeFinder
 
getCounts() - Method in class org.apache.pig.impl.util.LineageTracer
 
getCounts() - Method in class org.apache.pig.pen.util.LineageTracer
 
getCtorArgs() - Method in class org.apache.pig.FuncSpec
 
getCurPath() - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
getDataStorage() - Method in interface org.apache.pig.backend.datastorage.ElementDescriptor
 
getDataStorage() - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
 
getDataStorage() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
getDataStorage() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
getDataStorage() - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
getDataStorage() - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
getDetailedMessage() - Method in exception org.apache.pig.PigException
Returns the detailed message used by developers for debugging
getDeterminedSchema() - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
getDfs() - Method in class org.apache.pig.impl.PigContext
 
getDistinct(Tuple) - Method in class org.apache.pig.builtin.Distinct
 
getEndRow() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
getEnforcedSchema() - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
GetEquivalenceClasses(LogicalOperator, Map<LogicalOperator, DataBag>) - Static method in class org.apache.pig.pen.EquivalenceClasses
 
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
getErrorMessages(TaskReport[], String, boolean, PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.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.
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.backend.local.executionengine.LocalJob
 
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 class org.apache.pig.impl.logicalLayer.LOStream
 
getExecutionEngine() - Method in class org.apache.pig.impl.PigContext
 
getExpr() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryExpressionOperator
Get the contained expression.
getExpression() - Method in class org.apache.pig.impl.logicalLayer.LOCast
 
getExpression() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
getFailedFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.Launcher
Returns a list of locations of results that have failed.
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.
getFields() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
getFields() - Method in class org.apache.pig.impl.plan.RequiredFields
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.ExpressionOperator
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOAdd
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOAnd
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOBinCond
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOCast
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOConst
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LODivide
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOEqual
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOGreaterThan
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOGreaterThanEqual
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOIsNull
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOLesserThan
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOLesserThanEqual
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOMapLookup
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOMod
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOMultiply
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LONegative
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LONot
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LONotEqual
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOOr
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LORegexp
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOSubtract
 
getFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.LOUserFunc
 
getFileName() - Method in class org.apache.pig.impl.io.FileSpec
 
getFinal() - Method in interface org.apache.pig.Algebraic
 
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.COUNT
 
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.DoubleMax
 
getFinal() - Method in class org.apache.pig.builtin.DoubleMin
 
getFinal() - Method in class org.apache.pig.builtin.DoubleSum
 
getFinal() - Method in class org.apache.pig.builtin.FloatAvg
 
getFinal() - Method in class org.apache.pig.builtin.FloatMax
 
getFinal() - Method in class org.apache.pig.builtin.FloatMin
 
getFinal() - Method in class org.apache.pig.builtin.FloatSum
 
getFinal() - Method in class org.apache.pig.builtin.IntAvg
 
getFinal() - Method in class org.apache.pig.builtin.IntMax
 
getFinal() - Method in class org.apache.pig.builtin.IntMin
 
getFinal() - Method in class org.apache.pig.builtin.IntSum
 
getFinal() - Method in class org.apache.pig.builtin.LongAvg
 
getFinal() - Method in class org.apache.pig.builtin.LongMax
 
getFinal() - Method in class org.apache.pig.builtin.LongMin
 
getFinal() - Method in class org.apache.pig.builtin.LongSum
 
getFinal() - Method in class org.apache.pig.builtin.MAX
 
getFinal() - Method in class org.apache.pig.builtin.MIN
 
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.SUM
 
getFlatten() - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
getFlatten() - Method in class org.apache.pig.impl.logicalLayer.LOGenerate
 
getForEach() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POJoinPackage
 
getForEachPlans() - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
getFragment() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getFragment() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
getFragOp() - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
getFs() - Method in class org.apache.pig.impl.PigContext
 
getFuncName() - Method in class org.apache.pig.impl.io.FileSpec
 
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.impl.logicalLayer.LOUserFunc
 
getFuncSpecFromAlias(String) - Method in class org.apache.pig.impl.PigContext
 
getGeneratePlans() - Method in class org.apache.pig.impl.logicalLayer.LOGenerate
 
getGenerator() - Static method in class org.apache.pig.impl.plan.NodeIdGenerator
 
getGroupByPlans() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
getHandleSpecs(StreamingCommand.Handle) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get specifications for the given Handle.
getHFS() - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
getHFS() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
getId() - Method in interface org.apache.pig.backend.executionengine.ExecPhysicalOperator
 
getId() - Method in interface org.apache.pig.backend.executionengine.ExecScopedLogicalOperator
 
getId() - Method in class org.apache.pig.impl.plan.OperatorKey
 
getIndex() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SliceWrapper
 
getIndex() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
getIndex() - Method in class org.apache.pig.impl.io.PigNullableWritable
 
getInitial() - Method in interface org.apache.pig.Algebraic
 
getInitial() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getInitial() - Method in class org.apache.pig.builtin.AVG
 
getInitial() - Method in class org.apache.pig.builtin.COUNT
 
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.DoubleMax
 
getInitial() - Method in class org.apache.pig.builtin.DoubleMin
 
getInitial() - Method in class org.apache.pig.builtin.DoubleSum
 
getInitial() - Method in class org.apache.pig.builtin.FloatAvg
 
getInitial() - Method in class org.apache.pig.builtin.FloatMax
 
getInitial() - Method in class org.apache.pig.builtin.FloatMin
 
getInitial() - Method in class org.apache.pig.builtin.FloatSum
 
getInitial() - Method in class org.apache.pig.builtin.IntAvg
 
getInitial() - Method in class org.apache.pig.builtin.IntMax
 
getInitial() - Method in class org.apache.pig.builtin.IntMin
 
getInitial() - Method in class org.apache.pig.builtin.IntSum
 
getInitial() - Method in class org.apache.pig.builtin.LongAvg
 
getInitial() - Method in class org.apache.pig.builtin.LongMax
 
getInitial() - Method in class org.apache.pig.builtin.LongMin
 
getInitial() - Method in class org.apache.pig.builtin.LongSum
 
getInitial() - Method in class org.apache.pig.builtin.MAX
 
getInitial() - Method in class org.apache.pig.builtin.MIN
 
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.SUM
 
getInner() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
getInner() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
 
getInner() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
getInput() - Method in class org.apache.pig.impl.logicalLayer.LODistinct
 
getInput() - Method in class org.apache.pig.impl.logicalLayer.LOFilter
 
getInput() - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 
getInput() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
getInputArgsSchema() - Method in class org.apache.pig.FuncSpec
 
getInputColumns() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
getInputFile() - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
getInputPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
getInputPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POJoinPackage
 
getInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getInputs() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
getInputs() - Method in class org.apache.pig.impl.logicalLayer.LOCross
 
getInputs() - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
getInputs() - Method in class org.apache.pig.impl.logicalLayer.LOUnion
 
getInputSpec() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getInputSpec() - Method in class org.apache.pig.impl.logicalLayer.LOStore
 
getInputSpec() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get the input specification of the StreamingCommand.
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
getInstance() - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigHadoopLogger
 
getInstance() - Static method in class org.apache.pig.data.BagFactory
Get a reference to the singleton factory.
getInstance() - Static method in class org.apache.pig.data.TupleFactory
Get a reference to the singleton factory.
getIntermed() - Method in interface org.apache.pig.Algebraic
 
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.COUNT
 
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.DoubleMax
 
getIntermed() - Method in class org.apache.pig.builtin.DoubleMin
 
getIntermed() - Method in class org.apache.pig.builtin.DoubleSum
 
getIntermed() - Method in class org.apache.pig.builtin.FloatAvg
 
getIntermed() - Method in class org.apache.pig.builtin.FloatMax
 
getIntermed() - Method in class org.apache.pig.builtin.FloatMin
 
getIntermed() - Method in class org.apache.pig.builtin.FloatSum
 
getIntermed() - Method in class org.apache.pig.builtin.IntAvg
 
getIntermed() - Method in class org.apache.pig.builtin.IntMax
 
getIntermed() - Method in class org.apache.pig.builtin.IntMin
 
getIntermed() - Method in class org.apache.pig.builtin.IntSum
 
getIntermed() - Method in class org.apache.pig.builtin.LongAvg
 
getIntermed() - Method in class org.apache.pig.builtin.LongMax
 
getIntermed() - Method in class org.apache.pig.builtin.LongMin
 
getIntermed() - Method in class org.apache.pig.builtin.LongSum
 
getIntermed() - Method in class org.apache.pig.builtin.MAX
 
getIntermed() - Method in class org.apache.pig.builtin.MIN
 
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.SUM
 
getJobClient() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
getJobConf() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SliceWrapper
 
getJoinColPlans() - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
getJoinPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
getKey() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
 
getKeyAsTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
 
getKeyInfo() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
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.POPackageLite
 
getKeyType() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
 
getKeyType() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
 
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.POPackage
 
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
 
getLastAlias() - Method in class org.apache.pig.impl.PigContext
 
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.executionengine.PigSlice
 
getLength() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getLength() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SliceWrapper
 
getLength() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
getLength() - Method in interface org.apache.pig.Slice
Returns the length in bytes of all of the data that will be processed by this Slice.
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
 
getLhsOp() - Method in class org.apache.pig.impl.logicalLayer.LOBinCond
 
getLhsOperand() - Method in class org.apache.pig.impl.logicalLayer.BinaryExpressionOperator
 
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.POSort
 
getLimit() - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 
getLimit() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
getLoadFunc() - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
getLoadFuncSpec() - Method in class org.apache.pig.impl.logicalLayer.LOCast
 
getLoadFunction() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getLoads(PhysicalPlan) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.PlanHelper
Get all the load operators in the plan in the right dependency order
getLocation() - Method in class org.apache.pig.StoreConfig
 
getLocations() - Method in class org.apache.pig.backend.executionengine.PigSlice
 
getLocations() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getLocations() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SliceWrapper
 
getLocations() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
getLocations() - Method in interface org.apache.pig.Slice
Returns string representations of all the files that will be used as part of processing this Slice.
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
 
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
 
getLogs(OutputStream) - Method in class org.apache.pig.backend.local.executionengine.LocalJob
 
getLogToPhyMap() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.LocalLogToPhyTranslationVisitor
 
getLookUpKey() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getLookUpKey() - Method in class org.apache.pig.impl.logicalLayer.LOMapLookup
 
getMap() - Method in class org.apache.pig.impl.logicalLayer.LOMapLookup
 
getMappedFields() - Method in class org.apache.pig.impl.plan.ProjectionMap
 
getMAscCols() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
getMaterializedResults() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
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
 
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.NonSpillableDataBag
 
getMemorySize() - Method in class org.apache.pig.data.ReadOnceBag
 
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 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
 
getMessage() - Method in class org.apache.pig.impl.plan.CompilationMessageCollector.Message
 
getMessageCollector() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.CombinerOptimizer
 
getMessageCollector() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
getMessageType() - Method in class org.apache.pig.impl.plan.CompilationMessageCollector.Message
 
getMRPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
Used to get the compiled plan
getMRPlan() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getMSortFunc() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
getMultiInputNestedPlans(LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.DotLOPrinter
 
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.
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
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(LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.DotLOPrinter
 
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.
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(LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.DotLOPrinter
 
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.
getNewBaseData() - Method in class org.apache.pig.pen.AugmentBaseDataVisitor
 
getNewName() - Static method in class org.apache.pig.impl.logicalLayer.CanonicalNamer
 
getNext() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.DiscreteProbabilitySampleGenerator
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Add
 
getNext(Integer) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNext(Long) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNext(Double) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNext(Float) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNext(String) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNext(DataByteArray) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNext(Map) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNext(Boolean) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNext(Tuple) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNext(DataBag) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ComparisonOperator
 
getNext(DataBag) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNext(DataByteArray) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNext(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNext(Map) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Divide
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.EqualToExpr
 
getNext(DataBag) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GreaterThanExpr
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.GTOrEqualToExpr
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LessThanExpr
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.LTOrEqualToExpr
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Mod
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Mod
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Multiply
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.NotEqualToExpr
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POAnd
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNext(DataBag) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNext(DataByteArray) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNext(Map) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNext(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POBinCond
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNext(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNext(DataBag) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNext(Map) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POIsNull
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNext(DataBag) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNext(DataByteArray) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNext(Map) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNext(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONegative
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PONot
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POOr
 
getNext() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
Fetches the input tuple and returns the requested column
getNext(DataBag) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNext(DataByteArray) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNext(Map) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNext(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
Asked for Tuples.
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORegexp
 
getNext(DataBag) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.PORelationToExprProject
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNext(DataBag) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNext(DataByteArray) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNext(Map) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNext(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserComparisonFunc
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNext(DataBag) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNext(DataByteArray) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNext(Map) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNext(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.Subtract
 
getNext(Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNext(Long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNext(Double) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNext(Float) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNext(String) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNext(DataByteArray) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNext(Map) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNext(Boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNext(DataBag) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCombinerPackage
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODistinct
 
getNext(Tuple) - 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.
getNext(Tuple) - 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.
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POGlobalRearrange
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POJoinPackage
Calls getNext to get next ForEach result.
getNext(Tuple) - 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
getNext(Tuple) - 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.
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
Calls getNext on the generate operator inside the nested physical plan.
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMultiQueryPackage
Constructs the output tuple from the inputs.
getNext(Tuple) - 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.
getNext(Tuple) - 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}, ...)
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
Similar to POPackage.getNext except that only one input is expected with index 0 and ReadOnceBag is used instead of DefaultDataBag.
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
Calls getNext on the generate operator inside the nested physical plan.
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORead
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getNext(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
getNext(Tuple) - 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
getNext() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
getNext(Tuple) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.counters.POCounter
 
getNext(Tuple) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCogroup
 
getNext(Tuple) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCross
 
getNext(Tuple) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplit
 
getNext(Tuple) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplitOutput
 
getNext(Tuple) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POStreamLocal
This is different from the Map-Reduce implementation of the POStream since there is no push model here.
getNext() - Method in class org.apache.pig.builtin.BinaryStorage
 
getNext() - Method in class org.apache.pig.builtin.BinStorage
 
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.RandomSampleLoader
 
getNext() - Method in class org.apache.pig.impl.streaming.OutputHandler
Get the next output Tuple of the managed process.
getNext() - Method in interface org.apache.pig.LoadFunc
Retrieves the next tuple to be processed.
getNextHelper(Tuple) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
getNextNodeId(String) - Method in class org.apache.pig.impl.plan.NodeIdGenerator
 
getNextOpt() - Method in class org.apache.pig.tools.cmdline.CmdLineParser
Get the next option.
getNodeClass() - Method in class org.apache.pig.impl.plan.optimizer.RuleOperator
Get the node class of this operator.
getNodeType() - Method in class org.apache.pig.impl.plan.optimizer.RuleOperator
Get the node type of this operator.
getNumInps() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
getOperand() - Method in class org.apache.pig.impl.logicalLayer.LORegexp
 
getOperand() - Method in class org.apache.pig.impl.logicalLayer.UnaryExpressionOperator
 
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
 
getOperator(OperatorKey) - Method in class org.apache.pig.impl.plan.OperatorPlan
Given an OperatorKey, find the associated operator.
getOperatorKey() - Method in interface org.apache.pig.backend.executionengine.ExecScopedLogicalOperator
 
getOperatorKey() - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Get the operator key for this 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.
getOpsToBeReset() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
getOpTable() - Method in interface org.apache.pig.backend.executionengine.ExecPhysicalPlan
 
getOutputFile() - Method in class org.apache.pig.impl.logicalLayer.LOStore
 
getOutputs() - Method in class org.apache.pig.impl.logicalLayer.LOSplit
 
getOutputSpec() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get the specification of the primary output of the StreamingCommand.
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.
getOverloaded() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
getPackages() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMultiQueryPackage
Returns the list of packages.
getParser() - Method in class org.apache.pig.backend.executionengine.PigSlice
 
getParser() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getPartition(PigNullableWritable, Writable, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.WeightedRangePartitioner
 
getPath() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
getPath() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getPath() - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
getPathsToSkip() - Method in class org.apache.pig.impl.PigContext
Get paths which are to skipped while automatically shipping binaries for streaming.
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?
getPhysicalOpTable() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
getPhysicalPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
getPhysicalPlan() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getPigContext() - Method in class org.apache.pig.PigServer
 
getPigException(Throwable) - Static method in class org.apache.pig.impl.util.LogUtils
 
getPigLogger() - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getPigLogger() - Method in class org.apache.pig.EvalFunc
 
getPigStats() - Method in class org.apache.pig.tools.pigstats.PigStats
 
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.impl.logicalLayer.LogicalOperator
 
getPlan() - Method in class org.apache.pig.impl.plan.optimizer.Rule
 
getPlan() - Method in class org.apache.pig.impl.plan.PlanVisitor
 
getPlan() - Method in class org.apache.pig.impl.plan.PlanWalker
 
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.
getPos() - Method in class org.apache.pig.backend.executionengine.PigSlice
 
getPos() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
getPos() - Method in interface org.apache.pig.Slice
Returns the number of bytes read so far as part of processing this Slice.
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.
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.
getProgress() - Method in class org.apache.pig.backend.executionengine.PigSlice
 
getProgress() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
getProgress() - Method in interface org.apache.pig.Slice
Returns the percentage of Slice that is complete from 0.0 to 1.0.
getProjectedColsMap() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
getProjection() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOCross
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LODistinct
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOFilter
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Produce a map describing how this operator modifies its projection.
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOSplit
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOStore
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOStream
 
getProjectionMap() - Method in class org.apache.pig.impl.logicalLayer.LOUnion
 
getProjectList() - Method in class org.apache.pig.impl.logicalLayer.TopLevelProjectFinder
 
getProjectSet() - Method in class org.apache.pig.impl.logicalLayer.TopLevelProjectFinder
 
getProjectStarSet() - Method in class org.apache.pig.impl.logicalLayer.TopLevelProjectFinder
 
getProperties() - Method in class org.apache.pig.impl.PigContext
Provides configuration information.
getQuantFile() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getQuantileJob(POSort, MapReduceOper, FileSpec, FileSpec, int, Pair<Integer, Byte>[]) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
getR() - Static method in class org.apache.pig.impl.io.FileLocalizer
 
getReadFrom() - Method in class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
getRealness(LogicalOperator, Map<LogicalOperator, DataBag>, boolean) - Static method in class org.apache.pig.pen.util.MetricEvaluation
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
getRecordsWritten() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
In general, the mechanism for an OutputFormat in Pig to get hold of the storeFunc and the metadata information (for now schema and location provided for the store in the pig script) is through the following Utility static methods: MapRedUtil.getStoreFunc(JobConf) - this will get the StoreFunc reference to use in the RecordWriter.write() MapRedUtil.getStoreConfig(JobConf) - this will get the StoreConfig reference which has metadata like the location (the string supplied with store statement in the script) and the Schema of the data.
getRecordWriter(FileSystem, JobConf, Path, String, Progressable) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
 
getRegexp() - Method in class org.apache.pig.impl.logicalLayer.LORegexp
 
getRegionLocation() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
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.mapReduceLayer.MapReduceOper
 
getReplFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
getReporter() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigHadoopLogger
 
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.impl.logicalLayer.LogicalOperator
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOCross
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LODistinct
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOFilter
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Get a list of fields that this operator requires.
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOSplit
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOStore
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOStream
 
getRequiredFields() - Method in class org.apache.pig.impl.logicalLayer.LOUnion
 
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
 
getResults() - Method in class org.apache.pig.backend.local.executionengine.LocalJob
 
getResultType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
getReturnType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
getReturnType() - Method in class org.apache.pig.EvalFunc
 
getReverseCanonicalMap() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
 
getRhs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
getRhsOp() - Method in class org.apache.pig.impl.logicalLayer.LOBinCond
 
getRhsOperand() - Method in class org.apache.pig.impl.logicalLayer.BinaryExpressionOperator
 
getRoot() - Method in interface org.apache.pig.backend.executionengine.ExecPhysicalPlan
 
getRootJobIDs() - Method in class org.apache.pig.tools.pigstats.PigStats
 
getRoots() - Method in class org.apache.pig.impl.plan.OperatorPlan
Get a list of all nodes in the graph that are roots.
getRuleName() - Method in class org.apache.pig.impl.plan.optimizer.Rule
 
getSchema() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.ExpressionOperator
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOAdd
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOAnd
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOBinCond
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOCast
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOConst
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOCross
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LODefine
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LODistinct
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LODivide
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOEqual
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOFilter
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOGenerate
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Get a copy of the schema for the output of this operator.
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOGreaterThan
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOGreaterThanEqual
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOIsNull
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOLesserThan
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOLesserThanEqual
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOMapLookup
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOMod
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOMultiply
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LONegative
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LONot
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LONotEqual
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOOr
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LORegexp
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOSplit
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOStore
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOStream
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOSubtract
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOUnion
 
getSchema() - Method in class org.apache.pig.impl.logicalLayer.LOUserFunc
 
getSchema() - Method in class org.apache.pig.StoreConfig
 
getSchemaFile() - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
getSchemaName(String, Schema) - Method in class org.apache.pig.EvalFunc
 
getScope() - Method in interface org.apache.pig.backend.executionengine.ExecPhysicalOperator
 
getScope() - Method in interface org.apache.pig.backend.executionengine.ExecScopedLogicalOperator
 
getScope() - Method in class org.apache.pig.impl.plan.OperatorKey
 
getSentinel() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
getSFile() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
getShipCacheProperties() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
getShipFiles() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get whether files for this command should be shipped or not.
getShipSpecs() - Method in class org.apache.pig.impl.streaming.StreamingCommand
Get the list of files which need to be shipped to the cluster.
getSingleLeafPlanOutputOp() - Method in class org.apache.pig.impl.logicalLayer.LogicalPlan
 
getSingleLeafPlanOutputType() - Method in class org.apache.pig.impl.logicalLayer.LogicalPlan
 
getSize() - Method in class org.apache.pig.impl.io.FileSpec
 
getSlicer() - Method in class org.apache.pig.impl.io.ValidatingInputFileSpec
Returns the Slicer created by this spec's funcSpec.
getSortColPlans() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
getSortJob(POSort, MapReduceOper, FileSpec, FileSpec, int, Pair<Integer, Byte>[]) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
getSortOrder() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
getSortPlans() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
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.
getSplits(JobConf, int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
Creates input splits one per input and slices of it per DFS block of the input file.
getSplitStore() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
Returns the name of the file associated with this operator
getStackTraceElement(String) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.Launcher
 
getStart() - Method in class org.apache.pig.backend.executionengine.PigSlice
 
getStart() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getStart() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
getStart() - Method in interface org.apache.pig.Slice
Returns the offset from which data in this Slice will be processed.
getStartRow() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
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 interface org.apache.pig.backend.executionengine.ExecutionEngine
Provides statistics on the Execution Engine: number of nodes, node failure rates, average load, average job wait time...
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.HExecutionEngine
 
getStatistics() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getStatistics() - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
getStatistics() - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
getStatistics() - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
getStatistics() - Method in class org.apache.pig.backend.local.executionengine.LocalJob
 
getStats(Job, JobClient, boolean, PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.Launcher
 
getStatus() - Method in interface org.apache.pig.backend.executionengine.ExecJob
 
getStatus() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getStatus() - Method in class org.apache.pig.backend.local.executionengine.LocalJob
 
getSTDError(OutputStream) - Method in interface org.apache.pig.backend.executionengine.ExecJob
 
getSTDError(OutputStream) - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getSTDError(OutputStream) - Method in class org.apache.pig.backend.local.executionengine.LocalJob
 
getSTDOut(OutputStream) - Method in interface org.apache.pig.backend.executionengine.ExecJob
 
getSTDOut(OutputStream) - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
getSTDOut(OutputStream) - Method in class org.apache.pig.backend.local.executionengine.LocalJob
 
getStoreConfig(JobConf) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
This method is to be called from an OutputFormat.getRecordWriter(FileSystem ignored, JobConf job, String name, Progressable progress) method to obtain a reference to the StoreConfig object.
getStoreFunc(JobConf) - Static method in class org.apache.pig.backend.hadoop.executionengine.util.MapRedUtil
This method is to be called from an OutputFormat.getRecordWriter(FileSystem ignored, JobConf job, String name, Progressable progress) method to obtain a reference to the StoreFunc object to be used by that OutputFormat to perform the write() operation
getStoreFunc() - Method in class org.apache.pig.impl.logicalLayer.LOStore
 
getStorePreparationClass() - Method in class org.apache.pig.builtin.BinaryStorage
 
getStorePreparationClass() - Method in class org.apache.pig.builtin.BinStorage
 
getStorePreparationClass() - Method in class org.apache.pig.builtin.PigDump
 
getStorePreparationClass() - Method in class org.apache.pig.builtin.PigStorage
 
getStorePreparationClass() - Method in interface org.apache.pig.StoreFunc
Specify a backend specific class to use to prepare for storing output.
getStores(Job) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
Returns all store locations of a previously compiled job
getStores(PhysicalPlan) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.PlanHelper
Get all the store operators in the plan in the right dependency order
getStreamingCommand() - Method in class org.apache.pig.impl.logicalLayer.LOStream
Get the StreamingCommand object associated with this operator
getSucceededFiles() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.Launcher
Returns a list of locations of results that have been successfully completed.
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.
getTableName() - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
getTargetOps() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
getTargetOps() - Method in class org.apache.pig.data.TargetedTuple
 
getTemporaryPath(ElementDescriptor, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
getTimer(String) - Method in class org.apache.pig.tools.timer.PerformanceTimerFactory
Get a performance timer.
getTimeStamp() - Method in class org.apache.pig.data.TimestampedTuple
 
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.mapReduceLayer.Launcher
 
getTransformer() - Method in class org.apache.pig.impl.plan.optimizer.Rule
 
getTupIter() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
 
getTupleGroupBySchema() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
getTupleGroupBySchema(LOCogroup) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
getTupleJoinColSchema() - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
getType(int) - Method in class org.apache.pig.data.DefaultTuple
Find the type of a given field.
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() - Method in class org.apache.pig.impl.logicalLayer.ExpressionOperator
 
getType() - Method in class org.apache.pig.impl.logicalLayer.LOCross
 
getType() - Method in class org.apache.pig.impl.logicalLayer.LODistinct
 
getType() - Method in class org.apache.pig.impl.logicalLayer.LOFilter
 
getType() - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
getType() - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Get the type of this operator.
getType() - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 
getType() - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
getType() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
getType() - Method in class org.apache.pig.impl.logicalLayer.LOSplit
 
getType() - Method in class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
getType() - Method in class org.apache.pig.impl.logicalLayer.LOUnion
 
getType(int) - Method in class org.apache.pig.pen.util.ExampleTuple
 
getUDFs() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.UDFFinder
 
getUserDefinedSchema() - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
getUserDefinedSchema() - Method in class org.apache.pig.impl.logicalLayer.LOGenerate
 
getUserFunc() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
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 class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
getValue() - Method in class org.apache.pig.impl.logicalLayer.LOConst
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableBag
 
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.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.NullableText
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.NullableTuple
 
getValueAsPigType() - Method in class org.apache.pig.impl.io.PigNullableWritable
 
getValueTuple(NullableTuple, int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
getValueTuple(NullableTuple, int, Object) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
Makes use of the superclass method, but this requires an additional parameter key passed by ReadOnceBag.
getValueType() - Method in class org.apache.pig.impl.logicalLayer.LOMapLookup
 
getWalkerAlgo() - Method in class org.apache.pig.impl.plan.optimizer.Rule
 
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
 
getWorkingDir() - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
getWrapped() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SliceWrapper
 
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
 
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() - 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
 
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
 
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(InputStream, String) - Constructor for class org.apache.pig.tools.grunt.GruntParser
 
GruntParser(InputStream) - Constructor for class org.apache.pig.tools.grunt.GruntParser
 
GruntParser(PigScriptParserTokenManager) - Constructor for class org.apache.pig.tools.grunt.GruntParser
 
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

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
 
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
 
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
 
hasCompleted() - Method in class org.apache.pig.backend.local.executionengine.LocalJob
 
hasError() - Method in class org.apache.pig.impl.plan.CompilationMessageCollector
 
hashCode() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
hashCode() - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
hashCode() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter.InnerOperator
 
hashCode() - 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.ReadOnceBag
 
hashCode() - Method in class org.apache.pig.impl.io.PigNullableWritable
 
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.util.Pair
 
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.impl.util.RewindableIterator
 
hasNext(int) - Method in class org.apache.pig.impl.util.RewindableIterator
 
HBaseSlice - Class in org.apache.pig.backend.hadoop.hbase
HBase Slice to load a portion of range of a table.
HBaseSlice(byte[], byte[], byte[], byte[][], String) - Constructor for class org.apache.pig.backend.hadoop.hbase.HBaseSlice
Constructor
HBaseStorage - Class in org.apache.pig.backend.hadoop.hbase
A Slicer that split the hbase table into HBaseSlices.
HBaseStorage(String) - Constructor for class org.apache.pig.backend.hadoop.hbase.HBaseStorage
Constructor.
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
 
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
 
heartbeat - Variable in class org.apache.pig.data.TimestampedTuple
 
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
 
HJob - Class in org.apache.pig.backend.hadoop.executionengine
 
HJob(ExecJob.JOB_STATUS, PigContext, FileSpec) - Constructor for class org.apache.pig.backend.hadoop.executionengine.HJob
 
HJob(ExecJob.JOB_STATUS, PigContext, FileSpec, PigStats) - Constructor for class org.apache.pig.backend.hadoop.executionengine.HJob
 
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
 

I

id - Variable in class org.apache.pig.impl.plan.OperatorKey
 
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
ImmutableOutputStream - Class in org.apache.pig.backend.datastorage
 
ImmutableOutputStream(String) - Constructor for class org.apache.pig.backend.datastorage.ImmutableOutputStream
 
ImplicitSplitInserter - Class in org.apache.pig.impl.logicalLayer.optimizer
 
ImplicitSplitInserter(LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.optimizer.ImplicitSplitInserter
 
in - Variable in class org.apache.pig.builtin.BinaryStorage
 
in - Variable in class org.apache.pig.builtin.BinStorage
 
in - Variable in class org.apache.pig.builtin.PigStorage
 
index - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
inExplain - 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
Place holder for possible initialization activities.
init(DataStorage) - Method in class org.apache.pig.backend.executionengine.PigSlice
 
init() - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
init() - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
init(Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
init(DataStorage) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
init() - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
init() - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
init() - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
init(DataStorage) - Method in interface org.apache.pig.Slice
Initializes this Slice with the DataStorage it's to use to do its work.
INITIAL - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
initialized - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
 
initialized - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStream
 
initializeRefs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryComparisonOperator
 
inProcessing() - Method 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
 
inputAttached - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
inputBytes - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
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
 
InputOutputFileValidator - Class in org.apache.pig.impl.logicalLayer.validators
This validator does check 1) Input files referred to by all LOLoads exist 2) Output files referred to by all LOStores do not exist
InputOutputFileValidator(PigContext) - Constructor for class org.apache.pig.impl.logicalLayer.validators.InputOutputFileValidator
 
InputOutputFileVisitor - Class in org.apache.pig.impl.logicalLayer.validators
Visitor for checking input/output files Exceptions in here do not affect later operations so we don't throw any exception but log all of them in msgCollector.
InputOutputFileVisitor(LogicalPlan, CompilationMessageCollector, PigContext) - Constructor for class org.apache.pig.impl.logicalLayer.validators.InputOutputFileVisitor
 
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
 
insert(Tuple) - Method in class org.apache.pig.impl.util.LineageTracer
 
insert(Tuple) - Method in class org.apache.pig.pen.util.LineageTracer
 
insertAfter(LogicalOperator, LogicalOperator, Map<Integer, Integer>) - Method in class org.apache.pig.impl.logicalLayer.optimizer.LogicalTransformer
Insert a node in after an existing nodes.
insertBetween(LogicalOperator, LogicalOperator, LogicalOperator, Map<Integer, Integer>) - Method in class org.apache.pig.impl.logicalLayer.optimizer.LogicalTransformer
Insert a node in between two existing nodes.
insertBetween(E, E, E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Given two connected nodes add another node between them.
instantiateFuncFromAlias(String) - Method in interface org.apache.pig.impl.FunctionInstantiator
 
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
 
IntAvg - Class in org.apache.pig.builtin
Generates the average of the values of the first field of a tuple.
IntAvg() - Constructor for class org.apache.pig.builtin.IntAvg
 
IntAvg.Final - Class in org.apache.pig.builtin
 
IntAvg.Final() - Constructor for class org.apache.pig.builtin.IntAvg.Final
 
IntAvg.Initial - Class in org.apache.pig.builtin
 
IntAvg.Initial() - Constructor for class org.apache.pig.builtin.IntAvg.Initial
 
IntAvg.Intermediate - Class in org.apache.pig.builtin
 
IntAvg.Intermediate() - Constructor for class org.apache.pig.builtin.IntAvg.Intermediate
 
INTEGER - Static variable in class org.apache.pig.data.DataType
 
INTERMEDIATE - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
IntMax - Class in org.apache.pig.builtin
Generates the max of the values of the first field of a tuple.
IntMax() - Constructor for class org.apache.pig.builtin.IntMax
 
IntMax.Final - Class in org.apache.pig.builtin
 
IntMax.Final() - Constructor for class org.apache.pig.builtin.IntMax.Final
 
IntMax.Initial - Class in org.apache.pig.builtin
 
IntMax.Initial() - Constructor for class org.apache.pig.builtin.IntMax.Initial
 
IntMax.Intermediate - Class in org.apache.pig.builtin
 
IntMax.Intermediate() - Constructor for class org.apache.pig.builtin.IntMax.Intermediate
 
IntMin - Class in org.apache.pig.builtin
Generates the min of the Integer values in the first field of a tuple.
IntMin() - Constructor for class org.apache.pig.builtin.IntMin
 
IntMin.Final - Class in org.apache.pig.builtin
 
IntMin.Final() - Constructor for class org.apache.pig.builtin.IntMin.Final
 
IntMin.Initial - Class in org.apache.pig.builtin
 
IntMin.Initial() - Constructor for class org.apache.pig.builtin.IntMin.Initial
 
IntMin.Intermediate - Class in org.apache.pig.builtin
 
IntMin.Intermediate() - Constructor for class org.apache.pig.builtin.IntMin.Intermediate
 
IntSum - Class in org.apache.pig.builtin
Generates the sum of the Integer in the first field of a tuple.
IntSum() - Constructor for class org.apache.pig.builtin.IntSum
 
IntSum.Final - Class in org.apache.pig.builtin
 
IntSum.Final() - Constructor for class org.apache.pig.builtin.IntSum.Final
 
IntSum.Initial - Class in org.apache.pig.builtin
 
IntSum.Initial() - Constructor for class org.apache.pig.builtin.IntSum.Initial
 
IntSum.Intermediate - Class in org.apache.pig.builtin
 
IntSum.Intermediate() - Constructor for class org.apache.pig.builtin.IntSum.Intermediate
 
isAsynchronous() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
isAsynchronous() - Method in class org.apache.pig.EvalFunc
This function should be overriden to return true for functions that return their values asynchronously.
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.
isComplete(double) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.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.
isContainer(String) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
isContainer(String) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
isContainer(String) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
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
 
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.POLocalRearrange
 
isDistinct() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
isDistinct() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
 
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.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
 
isDone() - Method in class org.apache.pig.tools.grunt.GruntParser
 
isEmpty() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
IsEmpty - Class in org.apache.pig.builtin
 
IsEmpty() - Constructor for class org.apache.pig.builtin.IsEmpty
 
isEmpty() - Method in class org.apache.pig.impl.util.IdentityHashSet
 
isEmpty() - Method in class org.apache.pig.impl.util.MultiMap
 
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
 
isFrjoin() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isGlobalSort() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isHeartBeat() - Method in class org.apache.pig.data.TimestampedTuple
 
isInCombiner() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Returns a flag indicating if this operator is in a combiner.
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
 
isKeyTuple() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
isKeyTuple - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
isLimitAfterSort() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isLimited() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
isLimited() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
isMapDone() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isNull - Variable in class org.apache.pig.data.DefaultTuple
 
isNull(int) - Method in class org.apache.pig.data.DefaultTuple
Find out if a given field is null.
isNull() - Method in class org.apache.pig.data.DefaultTuple
 
isNull - Variable in class org.apache.pig.data.TargetedTuple
 
isNull(int) - Method in class org.apache.pig.data.TargetedTuple
 
isNull() - Method 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 interface org.apache.pig.data.Tuple
 
isNull() - Method in class org.apache.pig.impl.io.PigNullableWritable
 
isNull(int) - Method in class org.apache.pig.pen.util.ExampleTuple
 
isNull() - Method in class org.apache.pig.pen.util.ExampleTuple
 
isNumberType(byte) - Static method in class org.apache.pig.data.DataType
 
isOverloaded() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
isProjectStar() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
isReduceDone() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
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.
isSameMapKeyType() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Returns a flag indicating if all inner plans have the same map key type
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.
isSendEmptyBagOnEOP() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
isSingleLeafPlan() - Method in class org.apache.pig.impl.plan.OperatorPlan
 
isSingleProjection() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
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.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
 
isSplitable(FileSystem, Path) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
Is the given filename splitable? Usually, true, but if the file is stream compressed, it will not be.
isSplittable() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
isSplittable() - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
isSplitter() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isStar() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
isStar() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
isStar() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
isStreamInMap() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isStreamInReduce() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
isTmpStore() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
isToBeFlattenedArray - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
isTupleGroupCol() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
isTupleJoinCol() - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
isTwoLevelAccessRequired() - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
isUDFComparatorUsed - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
isUsableType(byte) - Static method in class org.apache.pig.data.DataType
 
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.
isVerbose - Variable in class org.apache.pig.impl.plan.PlanDumper
 
isVerbose() - Method in class org.apache.pig.impl.plan.PlanDumper
 
iterator() - Method in class org.apache.pig.backend.hadoop.datastorage.HDirectory
 
iterator() - Method in class org.apache.pig.backend.local.datastorage.LocalDir
 
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.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.IdentityHashSet
 
its - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 

J

JarManager - Class in org.apache.pig.impl.util
 
JarManager() - Constructor for class org.apache.pig.impl.util.JarManager
 
JOB_NAME - Static variable in class org.apache.pig.impl.PigContext
 
JOB_NAME_PREFIX - Static variable in class org.apache.pig.impl.PigContext
 
JOB_TRACKER_LOCATION - Static variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
jobClient - Variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
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.PigBagWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigBagWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigBagWritableComparator
 
JobControlCompiler.PigCharArrayWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigCharArrayWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigCharArrayWritableComparator
 
JobControlCompiler.PigDBAWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigDBAWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigDBAWritableComparator
 
JobControlCompiler.PigDoubleWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigDoubleWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigDoubleWritableComparator
 
JobControlCompiler.PigFloatWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigFloatWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigFloatWritableComparator
 
JobControlCompiler.PigIntWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigIntWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigIntWritableComparator
 
JobControlCompiler.PigLongWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigLongWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigLongWritableComparator
 
JobControlCompiler.PigTupleWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigTupleWritableComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigTupleWritableComparator
 
JobControlCompiler.PigWritableComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobControlCompiler.PigWritableComparator(Class) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler.PigWritableComparator
 
JobCreationException - Exception in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
JobCreationException() - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobCreationException
Create a new JobCreationException with null as the error message.
JobCreationException(String) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobCreationException
Create a new JobCreationException with the specified cause.
JobCreationException(String, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(String, int) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(String, int, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(String, int, byte) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.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.mapReduceLayer.JobCreationException
Create a new JobCreationException with the specified message and cause.
JobCreationException(String, int, boolean) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.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.mapReduceLayer.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.mapReduceLayer.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.mapReduceLayer.JobCreationException
Create a new JobCreationException with the specified message, error code, error source, retriable or not, detalied message for the developer and cause.
join(String, String[]) - Method in class org.apache.pig.impl.plan.PlanDumper
Helper function to print a string array.

K

keyAsTuple - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
keyInfo - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
keySet() - Method in class org.apache.pig.impl.util.MultiMap
Get a set of all the keys in this map.
keyType - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
 
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
 
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
 
kill() - Method in interface org.apache.pig.backend.executionengine.ExecJob
Kills current job.
kill() - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
kill() - Method in class org.apache.pig.backend.local.executionengine.LocalJob
 

L

Launcher - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
Launcher() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.Launcher
 
launchPig(PhysicalPlan, String, PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.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.local.executionengine.LocalPigLauncher
 
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
 
LENGTH_KEY - Static variable in interface org.apache.pig.backend.datastorage.ElementDescriptor
Available from getStatistics as a Long.
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
 
lhs - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
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>, Map<LogicalOperator, PhysicalOperator>, PhysicalPlan, PigContext) - Constructor for class org.apache.pig.pen.LineageTrimmingVisitor
 
listPaths(JobConf) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
List input directories.
listPaths(String) - Method in class org.apache.pig.PigServer
 
load(LoadFunc, PigContext) - Method in class org.apache.pig.impl.io.PigFile
 
loadCandidateKeywords(InputStream, Set<String>) - Static method in class org.apache.pig.tools.grunt.PigCompletor
 
LOAdd - Class in org.apache.pig.impl.logicalLayer
 
LOAdd(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOAdd
 
LoadFunc - Interface in org.apache.pig
This interface is used to implement functions to parse records from a dataset.
loadPropertiesFromFile(Properties) - Static method in class org.apache.pig.impl.util.PropertiesUtil
 
loadPropertiesFromFile() - Static method in class org.apache.pig.impl.util.PropertiesUtil
 
LOAnd - Class in org.apache.pig.impl.logicalLayer
 
LOAnd(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOAnd
 
LOBinCond - Class in org.apache.pig.impl.logicalLayer
 
LOBinCond(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOBinCond
 
LOCAL_PREFIX - Static variable in class org.apache.pig.impl.io.FileLocalizer
 
LocalDataStorage - Class in org.apache.pig.backend.local.datastorage
 
LocalDataStorage() - Constructor for class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
LocalDir - Class in org.apache.pig.backend.local.datastorage
 
LocalDir(LocalDataStorage, String) - Constructor for class org.apache.pig.backend.local.datastorage.LocalDir
 
LocalDir(LocalDataStorage, File) - Constructor for class org.apache.pig.backend.local.datastorage.LocalDir
 
LocalDir(LocalDataStorage, String, String) - Constructor for class org.apache.pig.backend.local.datastorage.LocalDir
 
LocalDir(LocalDataStorage, File, File) - Constructor for class org.apache.pig.backend.local.datastorage.LocalDir
 
LocalDir(LocalDataStorage, File, String) - Constructor for class org.apache.pig.backend.local.datastorage.LocalDir
 
LocalDir(LocalDataStorage, String, File) - Constructor for class org.apache.pig.backend.local.datastorage.LocalDir
 
LocalExecutionEngine - Class in org.apache.pig.backend.local.executionengine
 
LocalExecutionEngine(PigContext) - Constructor for class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
LocalFile - Class in org.apache.pig.backend.local.datastorage
 
LocalFile(LocalDataStorage, String) - Constructor for class org.apache.pig.backend.local.datastorage.LocalFile
 
LocalFile(LocalDataStorage, File) - Constructor for class org.apache.pig.backend.local.datastorage.LocalFile
 
LocalFile(LocalDataStorage, String, String) - Constructor for class org.apache.pig.backend.local.datastorage.LocalFile
 
LocalFile(LocalDataStorage, File, File) - Constructor for class org.apache.pig.backend.local.datastorage.LocalFile
 
LocalFile(LocalDataStorage, File, String) - Constructor for class org.apache.pig.backend.local.datastorage.LocalFile
 
LocalFile(LocalDataStorage, String, File) - Constructor for class org.apache.pig.backend.local.datastorage.LocalFile
 
LocalJob - Class in org.apache.pig.backend.local.executionengine
 
LocalJob(ExecJob.JOB_STATUS, PigContext, FileSpec) - Constructor for class org.apache.pig.backend.local.executionengine.LocalJob
 
LocalJob(ExecJob.JOB_STATUS, PigContext, FileSpec, PigStats) - Constructor for class org.apache.pig.backend.local.executionengine.LocalJob
 
LocalLogToPhyTranslationVisitor - Class in org.apache.pig.backend.local.executionengine.physicalLayer
 
LocalLogToPhyTranslationVisitor(LogicalPlan) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.LocalLogToPhyTranslationVisitor
 
LocalPath - Class in org.apache.pig.backend.local.datastorage
 
LocalPath(LocalDataStorage, String) - Constructor for class org.apache.pig.backend.local.datastorage.LocalPath
 
LocalPath(LocalDataStorage, File) - Constructor for class org.apache.pig.backend.local.datastorage.LocalPath
 
LocalPath(LocalDataStorage, String, String) - Constructor for class org.apache.pig.backend.local.datastorage.LocalPath
 
LocalPath(LocalDataStorage, File, File) - Constructor for class org.apache.pig.backend.local.datastorage.LocalPath
 
LocalPath(LocalDataStorage, File, String) - Constructor for class org.apache.pig.backend.local.datastorage.LocalPath
 
LocalPath(LocalDataStorage, String, File) - Constructor for class org.apache.pig.backend.local.datastorage.LocalPath
 
LocalPigLauncher - Class in org.apache.pig.backend.local.executionengine
 
LocalPigLauncher() - Constructor for class org.apache.pig.backend.local.executionengine.LocalPigLauncher
 
LocalPOStoreImpl - Class in org.apache.pig.backend.local.executionengine
This class implements the behavior of a POStore in the local execution engine.
LocalPOStoreImpl(PigContext) - Constructor for class org.apache.pig.backend.local.executionengine.LocalPOStoreImpl
 
LocalResult - Class in org.apache.pig.backend.local.executionengine
 
LocalResult(FileSpec) - Constructor for class org.apache.pig.backend.local.executionengine.LocalResult
 
LocalSeekableInputStream - Class in org.apache.pig.backend.local.datastorage
 
LocalSeekableInputStream(File) - Constructor for class org.apache.pig.backend.local.datastorage.LocalSeekableInputStream
 
LOCast - Class in org.apache.pig.impl.logicalLayer
 
LOCast(LogicalPlan, OperatorKey, byte) - Constructor for class org.apache.pig.impl.logicalLayer.LOCast
 
LOCogroup - Class in org.apache.pig.impl.logicalLayer
 
LOCogroup(LogicalPlan, OperatorKey, MultiMap<LogicalOperator, LogicalPlan>, boolean[]) - Constructor for class org.apache.pig.impl.logicalLayer.LOCogroup
 
LOConst - Class in org.apache.pig.impl.logicalLayer
 
LOConst(LogicalPlan, OperatorKey, Object) - Constructor for class org.apache.pig.impl.logicalLayer.LOConst
 
LOCross - Class in org.apache.pig.impl.logicalLayer
 
LOCross(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOCross
 
LODefine - Class in org.apache.pig.impl.logicalLayer
 
LODefine(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LODefine
 
LODistinct - Class in org.apache.pig.impl.logicalLayer
 
LODistinct(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LODistinct
 
LODivide - Class in org.apache.pig.impl.logicalLayer
 
LODivide(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LODivide
 
LOEqual - Class in org.apache.pig.impl.logicalLayer
 
LOEqual(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOEqual
 
LOFilter - Class in org.apache.pig.impl.logicalLayer
 
LOFilter(LogicalPlan, OperatorKey, LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.LOFilter
 
LOForEach - Class in org.apache.pig.impl.logicalLayer
 
LOForEach(LogicalPlan, OperatorKey, ArrayList<LogicalPlan>, ArrayList<Boolean>) - Constructor for class org.apache.pig.impl.logicalLayer.LOForEach
 
LOForEach(LogicalPlan, OperatorKey, ArrayList<LogicalPlan>, ArrayList<Boolean>, ArrayList<Schema>) - Constructor for class org.apache.pig.impl.logicalLayer.LOForEach
 
LOFRJoin - Class in org.apache.pig.impl.logicalLayer
This is the logical operator for the Fragment Replicate Join It holds the user specified information and is responsible for the schema computation.
LOFRJoin(LogicalPlan, OperatorKey, MultiMap<LogicalOperator, LogicalPlan>, boolean[], LogicalOperator) - Constructor for class org.apache.pig.impl.logicalLayer.LOFRJoin
 
LOG - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
log - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
 
log - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ExpressionOperator
 
log - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
log - Variable in class org.apache.pig.EvalFunc
 
log - Static variable in class org.apache.pig.impl.plan.OperatorPlan
 
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.impl.logicalLayer
 
LOGenerate(LogicalPlan, OperatorKey, ArrayList<LogicalPlan>, ArrayList<Boolean>) - Constructor for class org.apache.pig.impl.logicalLayer.LOGenerate
 
LOGenerate(LogicalPlan, OperatorKey, ArrayList<LogicalPlan>, ArrayList<Boolean>, ArrayList<Schema>) - Constructor for class org.apache.pig.impl.logicalLayer.LOGenerate
 
LOGenerate(LogicalPlan, OperatorKey, LogicalPlan, boolean) - Constructor for class org.apache.pig.impl.logicalLayer.LOGenerate
 
LogicalOperator - Class in org.apache.pig.impl.logicalLayer
Parent for all Logical operators.
LogicalOperator(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LogicalOperator
Equivalent to LogicalOperator(k, 0).
LogicalOperator(LogicalPlan, OperatorKey, int) - Constructor for class org.apache.pig.impl.logicalLayer.LogicalOperator
 
LogicalOptimizer - Class in org.apache.pig.impl.logicalLayer.optimizer
An optimizer for logical plans.
LogicalOptimizer(LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.optimizer.LogicalOptimizer
 
LogicalOptimizer(LogicalPlan, ExecType) - Constructor for class org.apache.pig.impl.logicalLayer.optimizer.LogicalOptimizer
 
LogicalOptimizer(LogicalPlan, ExecType, Set<String>) - Constructor for class org.apache.pig.impl.logicalLayer.optimizer.LogicalOptimizer
 
LogicalPlan - Class in org.apache.pig.impl.logicalLayer
 
LogicalPlan() - Constructor for class org.apache.pig.impl.logicalLayer.LogicalPlan
 
LogicalPlanBuilder - Class in org.apache.pig.impl.logicalLayer
PlanBuilder class outputs a logical plan given a query String and set of ValidIDs
LogicalPlanBuilder(PigContext) - Constructor for class org.apache.pig.impl.logicalLayer.LogicalPlanBuilder
 
LogicalPlanCloneHelper - Class in org.apache.pig.impl.logicalLayer
LogicalPlanCloneHelper implements a visitor mechanism to clone a logical plan and then patch up the connections held within the operators of the logical plan.
LogicalPlanCloneHelper(LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
LogicalPlanCloneHelper(LogicalPlan, Map<LogicalOperator, LogicalOperator>) - Constructor for class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
LogicalPlanCloner - Class in org.apache.pig.impl.logicalLayer
LogicalPlanCloner provides the only mechanism of cloning a logical plan and hence the the logical operators in the plan.
LogicalPlanCloner(LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.LogicalPlanCloner
 
LogicalPlanValidationExecutor - Class in org.apache.pig.impl.logicalLayer.validators
This class is responsible for all logical plan validations after the parsing stage.
LogicalPlanValidationExecutor(LogicalPlan, PigContext) - Constructor for class org.apache.pig.impl.logicalLayer.validators.LogicalPlanValidationExecutor
All the necessary validation logics can be plugged-in here.
logicalToPhysicalKeys - Variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
logicalToPhysicalKeys - Variable in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
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.
LogicalTransformer - Class in org.apache.pig.impl.logicalLayer.optimizer
 
LogicalTransformer(LogicalPlan, PlanWalker<LogicalOperator, LogicalPlan>) - Constructor for class org.apache.pig.impl.logicalLayer.optimizer.LogicalTransformer
 
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
 
LOGreaterThan - Class in org.apache.pig.impl.logicalLayer
 
LOGreaterThan(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOGreaterThan
 
LOGreaterThanEqual - Class in org.apache.pig.impl.logicalLayer
 
LOGreaterThanEqual(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOGreaterThanEqual
 
LogToPhyMap - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
LogToPhyTranslationVisitor - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer
 
LogToPhyTranslationVisitor(LogicalPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
LogUtils - Class in org.apache.pig.impl.util
 
LogUtils() - Constructor for class org.apache.pig.impl.util.LogUtils
 
LOIsNull - Class in org.apache.pig.impl.logicalLayer
 
LOIsNull(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOIsNull
 
LOLesserThan - Class in org.apache.pig.impl.logicalLayer
 
LOLesserThan(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOLesserThan
 
LOLesserThanEqual - Class in org.apache.pig.impl.logicalLayer
 
LOLesserThanEqual(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOLesserThanEqual
 
LOLimit - Class in org.apache.pig.impl.logicalLayer
 
LOLimit(LogicalPlan, OperatorKey, long) - Constructor for class org.apache.pig.impl.logicalLayer.LOLimit
 
LOLoad - Class in org.apache.pig.impl.logicalLayer
 
LOLoad(LogicalPlan, OperatorKey, FileSpec, ExecType, DataStorage, boolean) - Constructor for class org.apache.pig.impl.logicalLayer.LOLoad
 
LOMapLookup - Class in org.apache.pig.impl.logicalLayer
 
LOMapLookup(LogicalPlan, OperatorKey, Object, byte, Schema) - Constructor for class org.apache.pig.impl.logicalLayer.LOMapLookup
 
LOMod - Class in org.apache.pig.impl.logicalLayer
 
LOMod(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOMod
 
LOMultiply - Class in org.apache.pig.impl.logicalLayer
 
LOMultiply(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOMultiply
 
LONegative - Class in org.apache.pig.impl.logicalLayer
 
LONegative(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LONegative
 
LONG - Static variable in class org.apache.pig.data.DataType
 
LongAvg - Class in org.apache.pig.builtin
Generates the average of the values of the first field of a tuple.
LongAvg() - Constructor for class org.apache.pig.builtin.LongAvg
 
LongAvg.Final - Class in org.apache.pig.builtin
 
LongAvg.Final() - Constructor for class org.apache.pig.builtin.LongAvg.Final
 
LongAvg.Initial - Class in org.apache.pig.builtin
 
LongAvg.Initial() - Constructor for class org.apache.pig.builtin.LongAvg.Initial
 
LongAvg.Intermediate - Class in org.apache.pig.builtin
 
LongAvg.Intermediate() - Constructor for class org.apache.pig.builtin.LongAvg.Intermediate
 
LongMax - Class in org.apache.pig.builtin
Generates the max of the values of the first field of a tuple.
LongMax() - Constructor for class org.apache.pig.builtin.LongMax
 
LongMax.Final - Class in org.apache.pig.builtin
 
LongMax.Final() - Constructor for class org.apache.pig.builtin.LongMax.Final
 
LongMax.Initial - Class in org.apache.pig.builtin
 
LongMax.Initial() - Constructor for class org.apache.pig.builtin.LongMax.Initial
 
LongMax.Intermediate - Class in org.apache.pig.builtin
 
LongMax.Intermediate() - Constructor for class org.apache.pig.builtin.LongMax.Intermediate
 
LongMin - Class in org.apache.pig.builtin
Generates the min of the Long values in the first field of a tuple.
LongMin() - Constructor for class org.apache.pig.builtin.LongMin
 
LongMin.Final - Class in org.apache.pig.builtin
 
LongMin.Final() - Constructor for class org.apache.pig.builtin.LongMin.Final
 
LongMin.Initial - Class in org.apache.pig.builtin
 
LongMin.Initial() - Constructor for class org.apache.pig.builtin.LongMin.Initial
 
LongMin.Intermediate - Class in org.apache.pig.builtin
 
LongMin.Intermediate() - Constructor for class org.apache.pig.builtin.LongMin.Intermediate
 
LongSum - Class in org.apache.pig.builtin
Generates the sum of the Long values in the first field of a tuple.
LongSum() - Constructor for class org.apache.pig.builtin.LongSum
 
LongSum.Final - Class in org.apache.pig.builtin
 
LongSum.Final() - Constructor for class org.apache.pig.builtin.LongSum.Final
 
LongSum.Initial - Class in org.apache.pig.builtin
 
LongSum.Initial() - Constructor for class org.apache.pig.builtin.LongSum.Initial
 
LongSum.Intermediate - Class in org.apache.pig.builtin
 
LongSum.Intermediate() - Constructor for class org.apache.pig.builtin.LongSum.Intermediate
 
LONot - Class in org.apache.pig.impl.logicalLayer
 
LONot(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LONot
 
LONotEqual - Class in org.apache.pig.impl.logicalLayer
 
LONotEqual(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LONotEqual
 
LOOr - Class in org.apache.pig.impl.logicalLayer
 
LOOr(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOOr
 
LOPrinter - Class in org.apache.pig.impl.logicalLayer
A visitor mechanism printing out the logical plan.
LOPrinter(PrintStream, LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.LOPrinter
 
LOProject - Class in org.apache.pig.impl.logicalLayer
LOProject is designed like a singly linked list; A few examples will illustrate the point about the linked list nature of the design; a = load 'input1' as (name, age); b = group a by name; foreach b generate a, a.name; The project operator occurs in two places in the above script: generate a(here) and a.name(here) In the first occurrence, we are trying to project the elements of the bag a; In order to retrieve the bag, we need to project the the second column ($1) or column number 1 (using the zero based index) from the input (the relation or bag b) In the second occurence, we are trying to project the first column ($0) or column number 0 from the bag a which in turn is the column number 1 in the relation b; As you can see, the nested structure or the singly linked list nature is clearly visible; Given that it's a singly linked list, the null pointer or the sentinel is marked explictly using the boolean variable mSentinel; The sentinel is marked true only when the input is a relational operator; This occurs when we create the innermost operator
LOProject(LogicalPlan, OperatorKey, LogicalOperator, List<Integer>) - Constructor for class org.apache.pig.impl.logicalLayer.LOProject
 
LOProject(LogicalPlan, OperatorKey, LogicalOperator, Integer) - Constructor for class org.apache.pig.impl.logicalLayer.LOProject
 
LORegexp - Class in org.apache.pig.impl.logicalLayer
 
LORegexp(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LORegexp
 
LOSort - Class in org.apache.pig.impl.logicalLayer
 
LOSort(LogicalPlan, OperatorKey, List<LogicalPlan>, List<Boolean>, FuncSpec) - Constructor for class org.apache.pig.impl.logicalLayer.LOSort
 
LOSplit - Class in org.apache.pig.impl.logicalLayer
 
LOSplit(LogicalPlan, OperatorKey, ArrayList<LogicalOperator>) - Constructor for class org.apache.pig.impl.logicalLayer.LOSplit
 
LOSplitOutput - Class in org.apache.pig.impl.logicalLayer
 
LOSplitOutput(LogicalPlan, OperatorKey, int, LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
LOStore - Class in org.apache.pig.impl.logicalLayer
 
LOStore(LogicalPlan, OperatorKey, FileSpec) - Constructor for class org.apache.pig.impl.logicalLayer.LOStore
 
LOStream - Class in org.apache.pig.impl.logicalLayer
LOStream represents the specification of an external command to be executed in a Pig Query.
LOStream(LogicalPlan, OperatorKey, LogicalOperator, ExecutableManager, StreamingCommand) - Constructor for class org.apache.pig.impl.logicalLayer.LOStream
Create a new LOStream with the given command.
LOSubtract - Class in org.apache.pig.impl.logicalLayer
 
LOSubtract(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOSubtract
 
LOUnion - Class in org.apache.pig.impl.logicalLayer
 
LOUnion(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.LOUnion
 
LOUserFunc - Class in org.apache.pig.impl.logicalLayer
 
LOUserFunc(LogicalPlan, OperatorKey, FuncSpec, byte) - Constructor for class org.apache.pig.impl.logicalLayer.LOUserFunc
 
LOVisitor - Class in org.apache.pig.impl.logicalLayer
A visitor mechanism for navigating and operating on a tree of Logical Operators.
LOVisitor(LogicalPlan, PlanWalker<LogicalOperator, LogicalPlan>) - Constructor for class org.apache.pig.impl.logicalLayer.LOVisitor
 
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
 

M

main(String[]) - Static method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.DiscreteProbabilitySampleGenerator
 
Main - Class in org.apache.pig
 
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(String[]) - Static method in class org.apache.pig.StandAloneParser
 
main(String[]) - Static method in class org.apache.pig.tools.streams.StreamGenerator
 
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(LogicalPlan, PrintStream) - Method in class org.apache.pig.impl.logicalLayer.DotLOPrinter
 
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.
makeReader(JobConf) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SliceWrapper
 
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.
MalFormedProbVecException - Exception in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners
 
MalFormedProbVecException(String, int, byte) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.MalFormedProbVecException
 
MalFormedProbVecException() - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.MalFormedProbVecException
 
MalFormedProbVecException(String, Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.MalFormedProbVecException
 
MalFormedProbVecException(String) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.MalFormedProbVecException
 
MalFormedProbVecException(Throwable) - Constructor for exception org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.MalFormedProbVecException
 
mAlias - Variable in class org.apache.pig.impl.logicalLayer.LogicalOperator
Name of the record set that results from this operator.
map(Text, Tuple, OutputCollector<PigNullableWritable, Writable>, Reporter) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
The map function that attaches the inpTuple appropriately and executes the map plan if its not empty.
MAP - Static variable in class org.apache.pig.data.DataType
 
mapKeyType - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
mapPlan - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
MapRedResult - Class in org.apache.pig.backend.hadoop.executionengine
 
MapRedResult(FileSpec, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.MapRedResult
 
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
 
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(JobConf) - 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
 
MapSize - Class in org.apache.pig.builtin
Generates the size of the first field of a tuple.
MapSize() - Constructor for class org.apache.pig.builtin.MapSize
 
mapToString(Map<Object, Object>) - Static method in class org.apache.pig.data.DataType
 
mark(int) - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
mark(int) - Method in class org.apache.pig.backend.local.datastorage.LocalSeekableInputStream
 
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.NonSpillableDataBag
 
markStale(boolean) - Method in class org.apache.pig.data.ReadOnceBag
 
markStale(boolean) - Method in class org.apache.pig.data.SingleTupleBag
 
markSupported() - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
markSupported() - Method in class org.apache.pig.backend.local.datastorage.LocalSeekableInputStream
 
match(Rule<O, P>) - Method in class org.apache.pig.impl.plan.optimizer.RuleMatcher
Test a rule to see if it matches the current plan.
materializedResults - Variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
materializedResults - Variable in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
max(Tuple) - Static method in class org.apache.pig.builtin.DoubleMax
 
max(Tuple) - Static method in class org.apache.pig.builtin.FloatMax
 
max(Tuple) - Static method in class org.apache.pig.builtin.IntMax
 
max(Tuple) - Static method in class org.apache.pig.builtin.LongMax
 
MAX - Class in org.apache.pig.builtin
Generates the max of the values of the first field of a tuple.
MAX() - Constructor for class org.apache.pig.builtin.MAX
 
max(Tuple) - Static method in class org.apache.pig.builtin.MAX
 
max(Tuple) - Static method in class org.apache.pig.builtin.StringMax
 
MAX.Final - Class in org.apache.pig.builtin
 
MAX.Final() - Constructor for class org.apache.pig.builtin.MAX.Final
 
MAX.Initial - Class in org.apache.pig.builtin
 
MAX.Initial() - Constructor for class org.apache.pig.builtin.MAX.Initial
 
MAX.Intermediate - Class in org.apache.pig.builtin
 
MAX.Intermediate() - Constructor for class org.apache.pig.builtin.MAX.Intermediate
 
MAX_DATAATOM_LENGTH - Static variable in class org.apache.pig.pen.util.DisplayExamples
 
MAX_SPILL_FILES - Static variable in class org.apache.pig.data.DefaultAbstractBag
 
MAX_TASKS - Static variable in class org.apache.pig.impl.streaming.StreamingCommand
 
maxDoubles(Tuple) - Static method in class org.apache.pig.builtin.MAX
 
mBagFactory - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
mBagFactory - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
mBagFactory - Variable in class org.apache.pig.builtin.Utf8StorageConverter
 
mContents - Variable in class org.apache.pig.data.DefaultAbstractBag
 
mCurrentWalker - Variable in class org.apache.pig.impl.plan.PlanVisitor
Guaranteed to always point to the walker currently being used.
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.
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
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
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
 
mFieldSchema - Variable in class org.apache.pig.impl.logicalLayer.ExpressionOperator
 
mFromEdges - Variable in class org.apache.pig.impl.plan.OperatorPlan
 
min(Tuple) - Static method in class org.apache.pig.builtin.DoubleMin
 
min(Tuple) - Static method in class org.apache.pig.builtin.FloatMin
 
min(Tuple) - Static method in class org.apache.pig.builtin.IntMin
 
min(Tuple) - Static method in class org.apache.pig.builtin.LongMin
 
MIN - Class in org.apache.pig.builtin
Generates the min of the values of the first field of a tuple.
MIN() - Constructor for class org.apache.pig.builtin.MIN
 
min(Tuple) - Static method in class org.apache.pig.builtin.MIN
 
min(Tuple) - Static method in class org.apache.pig.builtin.StringMin
 
MIN.Final - Class in org.apache.pig.builtin
 
MIN.Final() - Constructor for class org.apache.pig.builtin.MIN.Final
 
MIN.Initial - Class in org.apache.pig.builtin
 
MIN.Initial() - Constructor for class org.apache.pig.builtin.MIN.Initial
 
MIN.Intermediate - Class in org.apache.pig.builtin
 
MIN.Intermediate() - Constructor for class org.apache.pig.builtin.MIN.Intermediate
 
mIndex - Variable in class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
minDoubles(Tuple) - Static method in class org.apache.pig.builtin.MIN
 
mIsDistinct - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
mIsFieldSchemaComputed - Variable in class org.apache.pig.impl.logicalLayer.ExpressionOperator
 
mIsSchemaComputed - Variable in class org.apache.pig.impl.logicalLayer.LogicalOperator
A boolean variable to remember if the schema has been computed
mkdirs(String) - Method in class org.apache.pig.PigServer
 
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
 
mLog - Variable in class org.apache.pig.builtin.PigStorage
 
mLog - Variable in class org.apache.pig.builtin.Utf8StorageConverter
 
mMaxIterations - Variable in class org.apache.pig.impl.plan.optimizer.PlanOptimizer
 
mMemSize - Variable in class org.apache.pig.data.DefaultAbstractBag
 
mMemSizeChanged - Variable in class org.apache.pig.data.DefaultAbstractBag
 
mMultiInputSubgraphs - Variable in class org.apache.pig.impl.plan.DotPlanDumper
 
mMultiOutputSubgraphs - Variable in class org.apache.pig.impl.plan.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
 
MODIFICATION_TIME_KEY - Static variable in interface org.apache.pig.backend.datastorage.ElementDescriptor
Available from getStatistics as a Long.
mOps - Variable in class org.apache.pig.impl.plan.OperatorPlan
 
mOpToCloneMap - Static variable in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
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.
mp - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
 
mPlan - Variable in class org.apache.pig.impl.logicalLayer.LogicalOperator
Logical plan that this operator is a part of.
mPlan - Variable in class org.apache.pig.impl.plan.optimizer.PlanOptimizer
 
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.
mRequestedParallelism - Variable in class org.apache.pig.impl.logicalLayer.LogicalOperator
Requested level of parallelism for this operation.
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
 
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
 
MRStreamHandler - 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 a POStream in it, this marks in the MROper whether the map has a POStream or if the reduce has a POStream.
MRStreamHandler(MROperPlan) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.MRStreamHandler
 
mRules - Variable in class org.apache.pig.impl.plan.optimizer.PlanOptimizer
 
mSchema - Variable in class org.apache.pig.impl.logicalLayer.LogicalOperator
Schema that defines the output of this operator.
mSize - Variable in class org.apache.pig.data.DefaultAbstractBag
 
mSpillFiles - Variable in class org.apache.pig.data.DefaultAbstractBag
 
mSubgraphs - Variable in class org.apache.pig.impl.plan.DotPlanDumper
 
mToEdges - Variable in class org.apache.pig.impl.plan.OperatorPlan
 
mTupleFactory - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
mTupleFactory - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
mTupleFactory - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
mTupleFactory - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
mTupleFactory - Variable in class org.apache.pig.builtin.Utf8StorageConverter
 
mTupleFactory - Static variable in class org.apache.pig.data.ReadOnceBag
 
mType - Variable in class org.apache.pig.impl.logicalLayer.LogicalOperator
Datatype of this output of this operator.
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
 
mValue - Variable in class org.apache.pig.impl.io.PigNullableWritable
 

N

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.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.POCombinerPackage
 
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.POGlobalRearrange
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POJoinPackage
 
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.POLocalRearrangeForIllustrate
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMultiQueryPackage
 
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.POPreCombinerLocalRearrange
 
name() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORead
 
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.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.local.executionengine.physicalLayer.counters.POCounter
 
name() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCogroup
 
name() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCross
 
name() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplit
 
name() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplitOutput
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOAdd
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOAnd
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOBinCond
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOCast
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOConst
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOCross
 
name() - Method in class org.apache.pig.impl.logicalLayer.LODefine
 
name() - Method in class org.apache.pig.impl.logicalLayer.LODistinct
 
name() - Method in class org.apache.pig.impl.logicalLayer.LODivide
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOEqual
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOFilter
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOGenerate
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOGreaterThan
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOGreaterThanEqual
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOIsNull
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOLesserThan
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOLesserThanEqual
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOMapLookup
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOMod
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOMultiply
 
name() - Method in class org.apache.pig.impl.logicalLayer.LONegative
 
name() - Method in class org.apache.pig.impl.logicalLayer.LONot
 
name() - Method in class org.apache.pig.impl.logicalLayer.LONotEqual
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOOr
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
name() - Method in class org.apache.pig.impl.logicalLayer.LORegexp
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOSplit
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOStore
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOStream
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOSubtract
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOUnion
 
name() - Method in class org.apache.pig.impl.logicalLayer.LOUserFunc
 
name() - Method in class org.apache.pig.impl.plan.Operator
 
name() - Method in class org.apache.pig.impl.plan.optimizer.RuleOperator
 
needAllFields() - Method in class org.apache.pig.impl.plan.RequiredFields
 
needNoFields() - Method in class org.apache.pig.impl.plan.RequiredFields
 
needsDistinctCombiner() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
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 from an existing list of tuples.
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.
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.DefaultTupleFactory
 
newTuple(int) - Method in class org.apache.pig.data.DefaultTupleFactory
 
newTuple(List) - Method in class org.apache.pig.data.DefaultTupleFactory
 
newTuple(Object) - Method in class org.apache.pig.data.DefaultTupleFactory
 
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.
newTupleNoCopy(List) - Method in class org.apache.pig.data.DefaultTupleFactory
 
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(Tuple) - Method in class org.apache.pig.backend.executionengine.PigSlice
 
next(Tuple) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseSlice
 
next() - Method in class org.apache.pig.impl.util.RewindableIterator
 
next(Tuple) - Method in interface org.apache.pig.Slice
Loads the next value from this Slice into value.
nodeGen - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
nodeIdGenerator - Variable in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
NodeIdGenerator - Class in org.apache.pig.impl.plan
 
noItems - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
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(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.
noRewind() - Method in class org.apache.pig.impl.util.RewindableIterator
 
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
 
NOTNULL - Static variable in interface org.apache.pig.data.Tuple
Marker for indicating whether the value this object holds is not a null
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
 
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(byte[]) - Constructor for class org.apache.pig.impl.io.NullableBytesWritable
 
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
 
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
 
numTypes() - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.operatorHelper
 
numTypes() - Static method in class org.apache.pig.data.DataType
 

O

ObjectSerializer - Class in org.apache.pig.impl.util
 
ObjectSerializer() - Constructor for class org.apache.pig.impl.util.ObjectSerializer
 
offset - Variable in class org.apache.pig.builtin.BinaryStorage
 
omittable - Variable in class org.apache.pig.pen.util.ExampleTuple
 
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(Properties) - Method in class org.apache.pig.backend.local.datastorage.LocalDir
 
open() - Method in class org.apache.pig.backend.local.datastorage.LocalDir
 
open(Properties) - Method in class org.apache.pig.backend.local.datastorage.LocalFile
 
open() - Method in class org.apache.pig.backend.local.datastorage.LocalFile
 
open() - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
open(String, ExecType, DataStorage) - Static method in class org.apache.pig.impl.io.FileLocalizer
This function returns an input stream to a local file system file or a file residing on Hadoop's DFS
open(String, 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
 
openIterator(String) - Method in class org.apache.pig.PigServer
Forces execution of query (and all queries from which it reads), in order to materialize result
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
 
operatorHelper - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.util
 
operatorHelper() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.util.operatorHelper
 
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
 
OpLimitOptimizer - Class in org.apache.pig.impl.logicalLayer.optimizer
A visitor to discover if any schema has been specified for a file being loaded.
OpLimitOptimizer(LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.optimizer.OpLimitOptimizer
 
OpLimitOptimizer(LogicalPlan, ExecType) - Constructor for class org.apache.pig.impl.logicalLayer.optimizer.OpLimitOptimizer
 
opsToBeReset - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
optimize() - Method in class org.apache.pig.impl.plan.optimizer.PlanOptimizer
Run the optimizer.
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.
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.executionengine.util - package org.apache.pig.backend.executionengine.util
 
org.apache.pig.backend.hadoop - package org.apache.pig.backend.hadoop
 
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.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.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.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.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.backend.local.datastorage - package org.apache.pig.backend.local.datastorage
 
org.apache.pig.backend.local.executionengine - package org.apache.pig.backend.local.executionengine
 
org.apache.pig.backend.local.executionengine.physicalLayer - package org.apache.pig.backend.local.executionengine.physicalLayer
 
org.apache.pig.backend.local.executionengine.physicalLayer.counters - package org.apache.pig.backend.local.executionengine.physicalLayer.counters
 
org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators - package org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators
 
org.apache.pig.builtin - package org.apache.pig.builtin
 
org.apache.pig.data - package org.apache.pig.data
Data types for Pig.
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.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.optimizer - package org.apache.pig.impl.logicalLayer.optimizer
 
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.pen - package org.apache.pig.pen
 
org.apache.pig.pen.util - package org.apache.pig.pen.util
 
org.apache.pig.tools.cmdline - package org.apache.pig.tools.cmdline
 
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.streams - package org.apache.pig.tools.streams
 
org.apache.pig.tools.timer - package org.apache.pig.tools.timer
 
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
 
outFileSpec - Variable in class org.apache.pig.backend.local.executionengine.LocalJob
 
outFileSpec - Variable in class org.apache.pig.backend.local.executionengine.LocalResult
 
outputBytes - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
outputCollector - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
 
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
 
outputRecords - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
outputs - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
outputSchema(Schema) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POUserFunc
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.ARITY
 
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.CONCAT
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.ConstantSize
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.COUNT
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.DoubleAvg
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.DoubleMax
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.DoubleMin
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.DoubleSum
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.FloatAvg
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.FloatMax
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.FloatMin
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.FloatSum
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.IntAvg
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.IntMax
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.IntMin
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.IntSum
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.LongAvg
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.LongMax
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.LongMin
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.LongSum
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.MapSize
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.MAX
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.MIN
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.RANDOM
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.SIZE
 
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.SUM
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.TOKENIZE
 
outputSchema(Schema) - Method in class org.apache.pig.builtin.TupleSize
 
outputSchema(Schema) - Method in class org.apache.pig.EvalFunc
 

P

pack - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
 
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
 
parallelismRequest - Variable in class org.apache.pig.backend.hadoop.executionengine.MapRedResult
 
ParameterSubstitutionPreprocessor - Class in org.apache.pig.tools.parameters
 
ParameterSubstitutionPreprocessor(int) - Constructor for class org.apache.pig.tools.parameters.ParameterSubstitutionPreprocessor
 
parentPlan - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
parse(String, String, Map<LogicalOperator, LogicalPlan>, Map<OperatorKey, LogicalOperator>, Map<String, LogicalOperator>, Map<String, String>) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanBuilder
 
parse(String, String, Map<LogicalOperator, LogicalPlan>, Map<OperatorKey, LogicalOperator>, Map<String, LogicalOperator>, int, Map<String, String>) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanBuilder
 
parseArguments(String) - Static method in class org.apache.pig.FuncSpec
Function to parse the arguments from a function specification argument list
parseCygPath(String, int) - Static method in class org.apache.pig.impl.io.FileLocalizer
Convert path from Windows convention to Unix convention.
parseExecType(String) - Static method in class org.apache.pig.PigServer
 
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.
path - Variable in class org.apache.pig.backend.hadoop.datastorage.HPath
 
path - Variable in class org.apache.pig.backend.local.datastorage.LocalPath
 
pc - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
PerformanceTimer - Class in org.apache.pig.tools.timer
 
PerformanceTimerFactory - Class in org.apache.pig.tools.timer
 
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
 
physicalOpTable - Variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
physicalOpTable - Variable in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
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
 
PIG_OUTPUT_FUNC - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat
 
PIG_STORE_CONFIG - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.JobControlCompiler
 
PIG_STORE_CONFIG - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReducePOStoreImpl
 
PigBytesRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigBytesRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigBytesRawComparator
 
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
 
PigCombiner.Combine() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
 
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
 
pigContext - Variable in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
pigContext - Variable in class org.apache.pig.backend.hadoop.executionengine.HJob
 
pigContext - Variable in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
pigContext - Variable in class org.apache.pig.backend.local.executionengine.LocalJob
 
PigContext - Class in org.apache.pig.impl
 
PigContext() - Constructor for class org.apache.pig.impl.PigContext
 
PigContext(ExecType, Properties) - Constructor for class org.apache.pig.impl.PigContext
 
PigDoubleRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigDoubleRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigDoubleRawComparator
 
PigDump - Class in org.apache.pig.builtin
 
PigDump() - Constructor for class org.apache.pig.builtin.PigDump
 
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(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, Throwable) - 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, Throwable) - 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, 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.
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
 
PigFloatRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigFloatRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigFloatRawComparator
 
PigHadoopLogger - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
A singleton class that implements the PigLogger interface for use in map reduce context.
PigInputFormat - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigInputFormat() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
PigIntRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigIntRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigIntRawComparator
 
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
 
PigLongRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigLongRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigLongRawComparator
 
PigMapBase - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigMapBase() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
 
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
 
PigMapOnly.Map() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapOnly.Map
 
PigMapReduce - 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.
PigMapReduce() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce
 
PigMapReduce.Map - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigMapReduce.Map() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Map
 
PigMapReduce.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.
PigMapReduce.MapWithComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.MapWithComparator
 
PigMapReduce.Reduce - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigMapReduce.Reduce() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
 
PigMapReduce.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.
PigMapReduce.ReduceWithComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.ReduceWithComparator
 
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
 
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
 
PigOutputFormat.PigRecordWriter(FileSystem, Path, StoreFunc) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigOutputFormat.PigRecordWriter
 
PigProgressable - Interface in org.apache.pig.backend.hadoop.executionengine.physicalLayer
 
PigServer - Class in org.apache.pig
This class is the program's connection to Pig.
PigServer(String) - 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(PigContext) - Constructor for class org.apache.pig.PigServer
 
PigServer(PigContext, boolean) - Constructor for class org.apache.pig.PigServer
 
PigSlice - Class in org.apache.pig.backend.executionengine
Slice that loads data using a LoadFunc.
PigSlice(String, FuncSpec, long, long) - Constructor for class org.apache.pig.backend.executionengine.PigSlice
 
PigSlicer - Class in org.apache.pig.backend.executionengine
Creates a slice per block size element in all files at location.
PigSlicer(FuncSpec) - Constructor for class org.apache.pig.backend.executionengine.PigSlicer
 
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(PigContext, FileSystem, Path, String, List<OperatorKey>, long, long) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit
 
PigStats - Class in org.apache.pig.tools.pigstats
 
PigStats() - Constructor for class org.apache.pig.tools.pigstats.PigStats
 
PigStorage - Class in org.apache.pig.builtin
A load function that parses a line of input into fields using a delimiter to set the fields.
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 regex as a field delimiter.
PigTextRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigTextRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTextRawComparator
 
PigTupleRawComparator - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
PigTupleRawComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleRawComparator
 
PigWarning - Enum in org.apache.pig
An enum to enumerate the warning types in Pig
plan - Variable in class org.apache.pig.impl.plan.PlanDumper
 
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
 
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.
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<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.impl.plan.optimizer
A class to optimize plans.
PlanOptimizer(P) - Constructor for class org.apache.pig.impl.plan.optimizer.PlanOptimizer
 
PlanOptimizer(P, int) - Constructor for class org.apache.pig.impl.plan.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
 
PlanPrinter<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.impl.plan
A visitor mechanism printing out the logical plan.
PlanPrinter(PrintStream, P) - Constructor for class org.apache.pig.impl.plan.PlanPrinter
 
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
 
PlanSetter - Class in org.apache.pig.impl.logicalLayer
A visitor to set plans correctly inside logical operators.
PlanSetter(LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.PlanSetter
 
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(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(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(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.
PlanValidationExecutor<P extends OperatorPlan> - Interface in org.apache.pig.impl.plan
This is an abstract of classes for plan validation executor
PlanValidator<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.impl.plan
Master of all plan validation classes.
PlanValidator() - Constructor for class org.apache.pig.impl.plan.PlanValidator
 
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
 
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
 
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
 
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
 
POCogroup - Class in org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators
This is a local implementation of Cogroup.
POCogroup(OperatorKey) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCogroup
 
POCogroup(OperatorKey, int) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCogroup
 
POCogroup(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCogroup
 
POCogroup(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCogroup
 
POCombinerPackage - 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.
POCombinerPackage(POPackage, boolean[]) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCombinerPackage
A new POPostCombinePackage will be constructed as a near clone of the provided POPackage.
POCounter - Class in org.apache.pig.backend.local.executionengine.physicalLayer.counters
 
POCounter(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.counters.POCounter
 
POCounter(OperatorKey, int) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.counters.POCounter
 
POCounter(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.counters.POCounter
 
POCounter(OperatorKey) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.counters.POCounter
 
POCross - Class in org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators
This is a local implementation of the cross.
POCross(OperatorKey) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCross
 
POCross(OperatorKey, int) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCross
 
POCross(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCross
 
POCross(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.local.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, List) - 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
 
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) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
POFRJoin(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
POFRJoin(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
POFRJoin(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
POFRJoin(OperatorKey, int, List<PhysicalOperator>, List<List<PhysicalPlan>>, List<Byte>, FileSpec[], int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
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
 
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
 
POJoinPackage - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POJoinPackage(OperatorKey, int, POPackage, POForEach) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POJoinPackage
 
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, boolean) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
POLoad(OperatorKey, FileSpec, boolean) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
POLoad(OperatorKey, int, FileSpec, boolean) - 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
 
POLocalRearrangeForIllustrate - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
The local rearrange operator is a part of the co-group implementation.
POLocalRearrangeForIllustrate(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrangeForIllustrate
 
POLocalRearrangeForIllustrate(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrangeForIllustrate
 
POLocalRearrangeForIllustrate(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrangeForIllustrate
 
POLocalRearrangeForIllustrate(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrangeForIllustrate
 
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, Object) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
POMultiQueryPackage - 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.
POMultiQueryPackage(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMultiQueryPackage
Constructs an operator with the specified key.
POMultiQueryPackage(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMultiQueryPackage
Constructs an operator with the specified key and degree of parallelism.
POMultiQueryPackage(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMultiQueryPackage
Constructs an operator with the specified key and inputs.
POMultiQueryPackage(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMultiQueryPackage
Constructs an operator with the specified key, degree of parallelism and inputs.
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
 
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
 
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
 
POPackageLite - 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.
POPackageLite(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
 
POPackageLite(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
 
POPackageLite(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
 
POPackageLite(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
 
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
 
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.
PORead - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
This operator is used to read tuples from a databag in memory.
PORead(OperatorKey) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORead
 
PORead(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORead
 
PORead(OperatorKey, int) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORead
 
PORead(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORead
 
PORead(OperatorKey, DataBag) - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORead
 
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
 
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.SortComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort.SortComparator
 
POSort.UDFSortComparator - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators
 
POSort.UDFSortComparator() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort.UDFSortComparator
 
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
POSplit - Class in org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators
 
POSplit(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplit
 
POSplit(OperatorKey, int) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplit
 
POSplit(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplit
 
POSplit(OperatorKey) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplit
 
POSplitOutput - Class in org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators
 
POSplitOutput(OperatorKey, int, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplitOutput
 
POSplitOutput(OperatorKey, int) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplitOutput
 
POSplitOutput(OperatorKey, List<PhysicalOperator>) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplitOutput
 
POSplitOutput(OperatorKey) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplitOutput
 
POStatus - Class in org.apache.pig.backend.hadoop.executionengine.physicalLayer
 
POStatus() - Constructor for class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
 
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
 
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
 
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
 
POStreamLocal - Class in org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators
 
POStreamLocal(OperatorKey, ExecutableManager, StreamingCommand, Properties) - Constructor for class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POStreamLocal
 
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
 
PreOrderDepthFirstWalker<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.pen.util
 
PreOrderDepthFirstWalker(P) - Constructor for class org.apache.pig.pen.util.PreOrderDepthFirstWalker
 
PreprocessorContext - Class in org.apache.pig.tools.parameters
 
PreprocessorContext(int) - Constructor for class org.apache.pig.tools.parameters.PreprocessorContext
 
print(OutputStream) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
print(OutputStream) - Method in class org.apache.pig.impl.logicalLayer.LOPrinter
 
print(OutputStream) - Method in class org.apache.pig.impl.plan.optimizer.RulePlanPrinter
 
print(OutputStream) - Method in class org.apache.pig.impl.plan.PlanPrinter
 
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.PigServer
 
printAliases() - Method in class org.apache.pig.tools.grunt.GruntParser
 
printHelp() - Method in class org.apache.pig.tools.grunt.GruntParser
 
PrintSimple(LogicalOperator, Map<LogicalOperator, DataBag>) - Static method in class org.apache.pig.pen.util.DisplayExamples
 
PrintTabular(LogicalPlan, Map<LogicalOperator, DataBag>) - Static method in class org.apache.pig.pen.util.DisplayExamples
 
processCat(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processCD(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processCopy(String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processCopyFromLocal(String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processCopyToLocal(String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processDescribe(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
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.tools.grunt.GruntParser
 
processIllustrate(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processingPlan - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
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.tools.grunt.GruntParser
 
processLS(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processMkdir(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processMove(String, String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
processNode(LOLimit) - Method in class org.apache.pig.impl.logicalLayer.optimizer.OpLimitOptimizer
 
processOnePackageOutput(OutputCollector<PigNullableWritable, Writable>) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner.Combine
 
processOnePackageOutput(OutputCollector<PigNullableWritable, Writable>) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.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.tools.grunt.GruntParser
 
processPlan() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
processPWD() - Method in class org.apache.pig.tools.grunt.GruntParser
 
processRegister(String) - Method in class org.apache.pig.tools.grunt.GruntParser
 
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.tools.grunt.GruntParser
 
processSet(String, 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
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
 
progress(String) - Method in interface org.apache.pig.backend.hadoop.executionengine.physicalLayer.PigProgressable
 
progress() - Method in class org.apache.pig.EvalFunc
 
PROGRESS_KEY - Static variable in interface org.apache.pig.backend.executionengine.ExecJob
 
ProgressableReporter - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
 
ProgressableReporter() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ProgressableReporter
 
ProgressableReporter(Reporter) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ProgressableReporter
 
progressOfRunningJob(Job, JobClient) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.Launcher
Returns the progress of a Job j which is part of a submitted JobControl object.
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, Pair<Integer, Integer>>, List<Pair<Integer, Integer>>, List<Integer>) - Constructor for class org.apache.pig.impl.plan.ProjectionMap
 
ProjectStarTranslator - Class in org.apache.pig.impl.logicalLayer
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), ...
ProjectStarTranslator(LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.ProjectStarTranslator
 
prompt() - Method in class org.apache.pig.tools.grunt.GruntParser
 
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
 
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.
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.
put(K, Integer) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.CountingMap
 
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.
putNext(Tuple) - Method in class org.apache.pig.builtin.BinaryStorage
 
putNext(Tuple) - Method in class org.apache.pig.builtin.BinStorage
 
putNext(Tuple) - Method in class org.apache.pig.builtin.PigDump
 
putNext(Tuple) - Method in class org.apache.pig.builtin.PigStorage
 
putNext(Tuple) - Method in class org.apache.pig.impl.streaming.InputHandler
Send the given input Tuple to the managed executable.
putNext(Tuple) - Method in interface org.apache.pig.StoreFunc
Write a tuple the output stream to which this instance was previously bound.

Q

QUANTILES_LIST - Static variable in class org.apache.pig.impl.builtin.FindQuantiles
 
quit() - Method in class org.apache.pig.tools.grunt.GruntParser
 

R

RANDOM - Class in org.apache.pig.builtin
 
RANDOM() - Constructor for class org.apache.pig.builtin.RANDOM
 
randomizeFileLocalizer() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
RandomSampleLoader - Class in org.apache.pig.impl.builtin
 
RandomSampleLoader() - Constructor for class org.apache.pig.impl.builtin.RandomSampleLoader
 
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
 
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() - Method in class org.apache.pig.backend.local.datastorage.LocalSeekableInputStream
 
read(byte[]) - Method in class org.apache.pig.backend.local.datastorage.LocalSeekableInputStream
 
read(byte[], int, int) - Method in class org.apache.pig.backend.local.datastorage.LocalSeekableInputStream
 
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
 
readDatum(DataInput) - Static method in class org.apache.pig.data.DataReaderWriter
 
readDatum(DataInput, byte) - Static method in class org.apache.pig.data.DataReaderWriter
 
readFields(DataInput) - Method in class org.apache.pig.backend.executionengine.PigSlice
 
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.mapReduceLayer.SliceWrapper
 
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.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.SingleTupleBag
 
readFields(DataInput) - Method in class org.apache.pig.data.TargetedTuple
 
readFields(DataInput) - Method in class org.apache.pig.impl.io.PigNullableWritable
 
readFields(DataInput) - Method in class org.apache.pig.pen.util.ExampleTuple
 
readLine(Charset, byte) - Method in class org.apache.pig.impl.io.BufferedPositionedInputStream
 
ReadOnceBag - Class in org.apache.pig.data
This bag is specifically created for use by POPackageLite.
ReadOnceBag(POPackageLite, Iterator<NullableTuple>, Object) - 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.
rebuildSchemas() - Method in class org.apache.pig.impl.logicalLayer.optimizer.LogicalTransformer
Rebuild schemas after a rule has transformed the tree.
reclaimScope(String) - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
A mechanism to communicate to the back-end that a set of logical plans go out of scope
reclaimScope(String) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
reclaimScope(String) - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
reconcile(Schema) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
Reconcile this schema with another schema.
reconcileSchema(Schema) - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Given a schema, reconcile it with our existing schema.
RECORD_1 - Static variable in class org.apache.pig.builtin.BinStorage
 
RECORD_2 - Static variable in class org.apache.pig.builtin.BinStorage
 
RECORD_3 - Static variable in class org.apache.pig.builtin.BinStorage
 
recordDelimiter - Static variable in class org.apache.pig.builtin.PigDump
 
reduce(PigNullableWritable, Iterator<NullableTuple>, OutputCollector<PigNullableWritable, Writable>, Reporter) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.DistinctCombiner.Combine
The reduce function which removes values.
reduce(PigNullableWritable, Iterator<NullableTuple>, OutputCollector<PigNullableWritable, Writable>, Reporter) - 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(PigNullableWritable, Iterator<NullableTuple>, OutputCollector<PigNullableWritable, Writable>, Reporter) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.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, Iterator<NullableTuple>, OutputCollector<PigNullableWritable, Writable>, Reporter) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.ReduceWithComparator
The reduce function which packages the key and List<Tuple> into key, Bag<Tuple> after converting Hadoop type key into Pig type.
reducePlan - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
reference(Tuple) - Method in class org.apache.pig.data.DefaultTuple
Make this tuple reference the contents of another.
reference(Tuple) - Method in class org.apache.pig.data.TargetedTuple
 
reference(Tuple) - Method in interface org.apache.pig.data.Tuple
Make this tuple reference the contents of another.
reference(Tuple) - Method in class org.apache.pig.pen.util.ExampleTuple
 
regenerateFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.ExpressionOperator
 
regenerateSchema() - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
 
registerBag(DataBag) - Method in class org.apache.pig.data.BagFactory
 
registerDeleteOnFail(String, PigContext) - Static method in class org.apache.pig.impl.io.FileLocalizer
 
registerFunction(String, FuncSpec) - Method in class org.apache.pig.impl.PigContext
Defines an alias for the given function spec.
registerFunction(String, String) - Method in class org.apache.pig.PigServer
Deprecated. 
registerFunction(String, FuncSpec) - Method in class org.apache.pig.PigServer
Defines an alias for the given function spec.
registerJar(String) - Method in class org.apache.pig.PigServer
Registers a jar file.
registerOpt(char, String, CmdLineParser.ValueExpected) - Method in class org.apache.pig.tools.cmdline.CmdLineParser
Register a command line option.
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
 
registerScript(String) - Method in class org.apache.pig.PigServer
 
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.
REMOTE_ENVIRONMENT - Static variable in exception org.apache.pig.PigException
 
remove(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
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.IdentityHashSet
 
remove(K, V) - Method in class org.apache.pig.impl.util.MultiMap
Remove one value from an existing key.
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).
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).
removeFromChain(LogicalOperator, Map<Integer, Integer>) - Method in class org.apache.pig.impl.logicalLayer.optimizer.LogicalTransformer
Remove a node in the middle of a linear chain.
removeKey(K) - Method in class org.apache.pig.impl.util.MultiMap
Remove all the values associated with the given key
removePlan(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
Removes plan from the nested input plan list
RemoveRedundantOperators - Class in org.apache.pig.impl.logicalLayer
A visitor to remove redundant operators in a plan
RemoveRedundantOperators(LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.RemoveRedundantOperators
 
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(ElementDescriptor) - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
rename(String, String) - Method in class org.apache.pig.impl.PigContext
 
renameFile(String, String) - Method in class org.apache.pig.PigServer
 
replace(PhysicalOperator, PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhysicalPlan
 
replace(E, E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Replace an existing node in the graph with a new node.
reporter - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
reporter - Variable in class org.apache.pig.ComparisonFunc
 
reporter - Variable in class org.apache.pig.EvalFunc
 
reportProgress() - Method in class org.apache.pig.data.DefaultAbstractBag
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
 
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.mapReduceLayer.JobControlCompiler
Resets the state
reset() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.Launcher
Resets the state after a launch
reset() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceLauncher
 
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.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.local.datastorage.LocalSeekableInputStream
 
reset(String) - Static method in class org.apache.pig.impl.plan.NodeIdGenerator
 
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.
resetState() - Static method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
resolveClassName(String) - Static method in class org.apache.pig.impl.PigContext
 
result - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
 
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 - Static variable in class org.apache.pig.pen.util.DisplayExamples
 
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
 
retriable - Variable in exception org.apache.pig.PigException
 
retriable() - Method in exception org.apache.pig.PigException
Checks if the exception is retriable.
returnStatus - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.Result
 
returnType - Variable in class org.apache.pig.EvalFunc
 
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
 
ReversibleLoadStoreFunc - Interface in org.apache.pig
This interface is used to implement classes that can perform both Load and Store functionalities in a symmetric fashion (thus reversible).
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
 
rhs - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryExpressionOperator
 
rp - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
 
Rule<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.impl.plan.optimizer
A rule for optimizing a plan.
Rule(RulePlan, Transformer<O, P>, String) - Constructor for class org.apache.pig.impl.plan.optimizer.Rule
 
Rule(RulePlan, Transformer<O, P>, String, Rule.WalkerAlgo) - Constructor for class org.apache.pig.impl.plan.optimizer.Rule
 
Rule.WalkerAlgo - Enum in org.apache.pig.impl.plan.optimizer
 
RuleMatcher<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.impl.plan.optimizer
RuleMatcher contains the logic to determine whether a given rule matches.
RuleMatcher() - Constructor for class org.apache.pig.impl.plan.optimizer.RuleMatcher
 
RuleOperator - Class in org.apache.pig.impl.plan.optimizer
Parent for all Logical operators.
RuleOperator(Class, OperatorKey) - Constructor for class org.apache.pig.impl.plan.optimizer.RuleOperator
 
RuleOperator(Class, RuleOperator.NodeType, OperatorKey) - Constructor for class org.apache.pig.impl.plan.optimizer.RuleOperator
 
RuleOperator.NodeType - Enum in org.apache.pig.impl.plan.optimizer
 
RulePlan - Class in org.apache.pig.impl.plan.optimizer
 
RulePlan() - Constructor for class org.apache.pig.impl.plan.optimizer.RulePlan
 
RulePlanPrinter - Class in org.apache.pig.impl.plan.optimizer
A visitor mechanism printing out the logical plan.
RulePlanPrinter(PrintStream, RulePlan) - Constructor for class org.apache.pig.impl.plan.optimizer.RulePlanPrinter
 
RulePlanVisitor - Class in org.apache.pig.impl.plan.optimizer
 
RulePlanVisitor(RulePlan, PlanWalker<RuleOperator, RulePlan>) - Constructor for class org.apache.pig.impl.plan.optimizer.RulePlanVisitor
 
run() - Method in class org.apache.pig.impl.streaming.ExecutableManager
Start execution of the ExecutableManager.
run() - Method in class org.apache.pig.tools.grunt.Grunt
 
runningJobs(Properties) - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Return currently running jobs (can be useful for admin purposes)
runningJobs(Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
runningJobs(Properties) - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
runPipeline(PhysicalOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
 

S

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.FieldSchema - Class in org.apache.pig.impl.logicalLayer.schema
 
Schema.FieldSchema(String, byte) - Constructor for class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Constructor for any type.
Schema.FieldSchema(String, Schema) - Constructor for class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Constructor for tuple fields.
Schema.FieldSchema(String, Schema, byte) - Constructor for class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Constructor for tuple fields.
Schema.FieldSchema(Schema.FieldSchema) - Constructor for class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Copy Constructor.
SchemaCalculator - Class in org.apache.pig.impl.logicalLayer.optimizer
A visitor to reset all the schemas in a logical plan.
SchemaCalculator(LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
schemaEqualsForMatching(Schema, Schema, boolean) - Static method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
Compare two schemas for equality for argument matching purposes.
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.
SchemaRemover - Class in org.apache.pig.impl.logicalLayer.optimizer
A visitor to reset all the schemas in a logical plan.
SchemaRemover(LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
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
 
second - Variable in class org.apache.pig.impl.util.Pair
 
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, SeekableInputStream.FLAGS) - Method in class org.apache.pig.backend.local.datastorage.LocalSeekableInputStream
 
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
 
serialize(Serializable) - Static method in class org.apache.pig.impl.util.ObjectSerializer
 
serializer - Variable in class org.apache.pig.impl.streaming.InputHandler
 
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.POLocalRearrange
 
serialVersionUID - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
set(double) - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
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(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.pen.util.ExampleTuple
 
setActiveContainer(ContainerDescriptor) - Method in interface org.apache.pig.backend.datastorage.DataStorage
 
setActiveContainer(ContainerDescriptor) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
setActiveContainer(ContainerDescriptor) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
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.impl.logicalLayer.LogicalOperator
 
setAmendKey(Object) - Method in class org.apache.pig.data.AmendableTuple
 
setAscendingCols(List<Boolean>) - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
setBaseIndex(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Sets the base index of this demux.
setBaseIndex(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMultiQueryPackage
Sets the base index of this operator
setBatchOn() - Method in class org.apache.pig.PigServer
Starts batch execution mode.
setCanonicalNames() - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Calculate canonical names for all fields in the schema.
setChanges(boolean) - Method in class org.apache.pig.impl.plan.ProjectionMap
 
setChunkSize(long) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POJoinPackage
 
setClassName(String) - Method in class org.apache.pig.FuncSpec
 
setColumn(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
setColumns(ArrayList<Integer>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
setCommandArgs(String[]) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Set the command line arguments for the StreamingCommand.
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.PigBytesRawComparator
 
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.PigTextRawComparator
 
setConf(Configuration) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigTupleRawComparator
 
setConsoleReader(ConsoleReader) - Method in class org.apache.pig.tools.grunt.Grunt
 
setCross(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
setCtorArgs(String[]) - Method in class org.apache.pig.FuncSpec
 
setDetailedMessage(String) - Method in exception org.apache.pig.PigException
Set the detailed message of the exception
setDistinct(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
 
setDistinct(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
setDistinct(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
 
setEnforcedSchema(Schema) - Method in class org.apache.pig.impl.logicalLayer.LOLoad
Set this when user enforces schema
setErrorCode(int) - Method in exception org.apache.pig.PigException
Set the error code of the exception
setErrorSource(byte) - Method in exception org.apache.pig.PigException
Set the error source of the exception
setException(Exception) - Method in class org.apache.pig.backend.hadoop.executionengine.HJob
 
setExecType(ExecType) - Method in class org.apache.pig.impl.PigContext
 
setExecType(ExecType) - Method in class org.apache.pig.tools.pigstats.PigStats
 
setExecutable(String) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Set the executable for the StreamingCommand.
setExpr(ExpressionOperator) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.UnaryExpressionOperator
Set the contained expression explicitly.
setExpression(LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
setFields(List<Pair<Integer, Integer>>) - Method in class org.apache.pig.impl.plan.RequiredFields
 
setFieldSchema(Schema.FieldSchema) - Method in class org.apache.pig.impl.logicalLayer.ExpressionOperator
Set the output schema for this operator.
setFieldSchemaDefaultType(Schema.FieldSchema, byte) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Recursively set NULL type to the specifid type
setFlatten(ArrayList<Boolean>) - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
setForEachPlans(ArrayList<LogicalPlan>) - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
setFragment(int) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setFragment(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
setFragOp(LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
setFrjoin(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setFuncSpec(FuncSpec) - Method in class org.apache.pig.impl.logicalLayer.LOUserFunc
 
setGlobalSort(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setGroupByPlans(MultiMap<LogicalOperator, LogicalPlan>) - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
setHeartBeat(boolean) - Method in class org.apache.pig.data.TimestampedTuple
 
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(byte) - Method in class org.apache.pig.impl.io.PigNullableWritable
 
setInner(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
setInner(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
 
setInner(boolean[]) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCogroup
 
setInner(boolean[]) - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
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.
setInputFile(FileSpec) - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
setInputPlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
setInputPlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POJoinPackage
 
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
 
setInputSpec(FileSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setInputSpec(FileSpec) - Method in class org.apache.pig.impl.logicalLayer.LOStore
 
setInputSpec(StreamingCommand.HandleSpec) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Set the input specification for the StreamingCommand.
setIsTmpStore(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setJobClient(JobClient) - Method in class org.apache.pig.tools.pigstats.PigStats
 
setJobControl(JobControl) - Method in class org.apache.pig.tools.pigstats.PigStats
 
setJobName(String) - Method in class org.apache.pig.PigServer
 
setJobtrackerLocation(String) - Method in class org.apache.pig.impl.PigContext
 
setKeyInfo(Map<Integer, Pair<Boolean, Map<Integer, Integer>>>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCombinerPackage
 
setKeyInfo(Map<Integer, Pair<Boolean, Map<Integer, Integer>>>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
setKeyTuple(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
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.PigMapBase
 
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.POPackage
 
setKeyType(byte) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPreCombinerLocalRearrange
 
setLastAlias(String) - Method in class org.apache.pig.impl.PigContext
 
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.POSort
 
setLimit(long) - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 
setLimit(long) - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
setLimitAfterSort(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setLineageTracer(LineageTracer) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setLoadFSpec(FuncSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POCast
 
setLoadFuncSpec(FuncSpec) - Method in class org.apache.pig.impl.logicalLayer.LOCast
 
setLoadOnly(boolean) - Method in class org.apache.pig.tools.grunt.GruntParser
 
setLocation(String) - Method in class org.apache.pig.StoreConfig
 
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.
setLookUpKey(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POMapLookUp
 
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
 
setMappedFields(MultiMap<Integer, Pair<Integer, Integer>>) - Method in class org.apache.pig.impl.plan.ProjectionMap
 
setMaxRecords(int) - Method in class org.apache.pig.pen.ExampleGenerator
 
setMROperatorPlan(MROperPlan) - Method in class org.apache.pig.tools.pigstats.PigStats
 
setMSortFunc(POUserComparisonFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
setMultiQueryIndex(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLocalRearrange
Sets the multi-query index of this operator
setName(String) - Method in class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
Set the name of the HandleSpec.
setNeedAllFields(boolean) - Method in class org.apache.pig.impl.plan.RequiredFields
 
setNeedNoFields(boolean) - Method in class org.apache.pig.impl.plan.RequiredFields
 
setNeedsDistinctCombiner(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setNodeType(RuleOperator.NodeType) - Method in class org.apache.pig.impl.plan.optimizer.RuleOperator
Set the node type of this rule operator.
setNull(boolean) - Method in class org.apache.pig.data.DefaultTuple
 
setNull(boolean) - Method in class org.apache.pig.data.TargetedTuple
 
setNull(boolean) - Method in interface org.apache.pig.data.Tuple
 
setNull(boolean) - Method in class org.apache.pig.impl.io.PigNullableWritable
 
setNull(boolean) - Method in class org.apache.pig.pen.util.ExampleTuple
 
setNumInps(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackage
 
setNumInps(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POPackageLite
 
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
 
setOperatorToEvaluate(LogicalOperator) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
setOpsToBeReset(List<PhysicalOperator>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
setOptimizedSpec(StreamingCommand.Handle, String) - Method in class org.apache.pig.impl.logicalLayer.LOStream
Set the optimized StreamingCommand.HandleSpec for the given StreamingCommand.Handle of the StreamSpec.
setOutputFile(FileSpec) - Method in class org.apache.pig.impl.logicalLayer.LOStore
 
setOutputs(ArrayList<LogicalOperator>) - Method in class org.apache.pig.impl.logicalLayer.LOSplit
 
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
 
setOverloaded(boolean) - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
setParams(PigServer) - Method in class org.apache.pig.tools.grunt.GruntParser
 
setParent(String, LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
 
setParentPlan(PhysicalPlan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setPc(PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POLoad
 
setPersistStderr(boolean) - Method in class org.apache.pig.impl.streaming.StreamingCommand
Specify if the stderr of the managed process should be persisted.
setPhysicalPlan(PhysicalPlan) - Method in class org.apache.pig.tools.pigstats.PigStats
 
setPigContext(PigContext) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
setPigLogger(PigLogger) - Static method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setPigLogger(PigLogger) - Method in class org.apache.pig.EvalFunc
 
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(PhysicalPlan) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplitOutput
 
setPlan(LogicalPlan) - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Change the reference to the plan for this operator.
setPlan(P) - Method in class org.apache.pig.impl.plan.PlanWalker
 
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
 
setProjection(List<Integer>) - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
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
 
setReduceDone(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setRemovedFields(List<Pair<Integer, Integer>>) - Method in class org.apache.pig.impl.plan.ProjectionMap
 
setRep(Reporter) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.ProgressableReporter
 
setReplFiles(FileSpec[]) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setReplFiles(FileSpec[]) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POFRJoin
 
setReporter(Reporter) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReducePOStoreImpl
 
setReporter(Reporter) - 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
 
setReporter(PigProgressable) - Method in class org.apache.pig.EvalFunc
 
setRequestedParallelism(int) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
setRequestedParallelism(int) - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
 
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.PhysicalOperator
 
setRetriable(boolean) - Method in exception org.apache.pig.PigException
Set the retriable attribute of the exception
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
 
setSameMapKeyType(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PODemux
Sets a flag indicating if all inner plans have the same map key type.
setSchema(Schema) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setSchema(Schema) - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Set the output schema for this operator.
setSchema(Schema) - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
setSchema(Schema) - Method in class org.apache.pig.StoreConfig
 
setSchemaComputed(boolean) - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
IMPORTANT: This method is only used for unit testing purpose.
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
setSendEmptyBagOnEOP(boolean) - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
setSentinel(boolean) - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
setSFile(FileSpec) - 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.
setSortColPlans(List<LogicalPlan>) - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
setSortOrder(boolean[]) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setSortPlans(List<PhysicalPlan>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSort
 
setSpec(String) - Method in class org.apache.pig.impl.streaming.StreamingCommand.HandleSpec
Set the serializer/deserializer spec of the HandleSpec.
setSplitStore(FileSpec) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POSplit
Sets the name of the file associated with this operator
setSplittable(boolean) - Method in class org.apache.pig.backend.executionengine.PigSlicer
 
setSplitter(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setStar(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.POProject
 
setStar(boolean) - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
setStar(boolean) - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
setStoreImpl(POStoreImpl) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
 
setStreamInMap(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setStreamInReduce(boolean) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
setTargetOps(List<OperatorKey>) - Method in class org.apache.pig.data.TargetedTuple
 
setTimeStamp(double) - Method in class org.apache.pig.data.TimestampedTuple
 
setToBeFlattened(List<Boolean>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
setToBeFlattened(List<Boolean>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POJoinPackage
 
setTwoLevelAccessRequired(boolean) - Method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
setType(byte) - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Set the type of this operator.
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
setUp() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POStore
Set up the storer
setupEnvironment(ProcessBuilder) - Method in class org.apache.pig.impl.streaming.ExecutableManager
Set up the run-time environment of the managed process.
setUpFlattens(List<Boolean>) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POForEach
 
setUserDefinedSchema(ArrayList<Schema>) - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
setUserFunc(FuncSpec) - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
setValue(Object) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.ConstantExpression
 
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.impl.logicalLayer.LOPrinter
 
setVerbose(boolean) - Method in class org.apache.pig.impl.plan.PlanDumper
 
shutdown() - Method in class org.apache.pig.PigServer
 
simpleConnectMapToReduce(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
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
 
SIZE - Class in org.apache.pig.builtin
Generates the Size of the first field of a tuple.
SIZE() - Constructor for class org.apache.pig.builtin.SIZE
 
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.NonSpillableDataBag
 
size() - Method in class org.apache.pig.data.ReadOnceBag
 
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.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.util.IdentityHashSet
 
size() - Method in class org.apache.pig.impl.util.MultiMap
Get the number of entries in the map.
size() - Method in class org.apache.pig.pen.util.ExampleTuple
 
sJob - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
sJobConf - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigCombiner
 
sJobConf - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce
 
skip(long) - Method in class org.apache.pig.backend.hadoop.datastorage.HSeekableInputStream
 
skip(long) - Method in class org.apache.pig.backend.local.datastorage.LocalSeekableInputStream
 
skip(long) - Method in class org.apache.pig.impl.io.BufferedPositionedInputStream
 
skip(long) - Method in class org.apache.pig.impl.io.FileLocalizer.DataStorageInputStreamIterator
 
skipJars - Variable in class org.apache.pig.impl.PigContext
 
slice(DataStorage, String) - Method in class org.apache.pig.backend.executionengine.PigSlicer
 
slice(DataStorage, String) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
Slice - Interface in org.apache.pig
A grouping of data on that can be processed individually by Pig.
slice(DataStorage, String) - Method in interface org.apache.pig.Slicer
Creates slices of data from store at location.
Slicer - Interface in org.apache.pig
Produces independent slices of data from a given location to be processed in parallel by Pig.
SliceWrapper - Class in org.apache.pig.backend.hadoop.executionengine.mapReduceLayer
Wraps a Slice in an InputSplit so it's usable by hadoop.
SliceWrapper() - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SliceWrapper
 
SliceWrapper(Slice, PigContext, int, FileSystem, ArrayList<OperatorKey>) - Constructor for class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SliceWrapper
 
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
 
sopen(Properties) - Method in class org.apache.pig.backend.local.datastorage.LocalDir
 
sopen() - Method in class org.apache.pig.backend.local.datastorage.LocalDir
 
sopen(Properties) - Method in class org.apache.pig.backend.local.datastorage.LocalFile
 
sopen() - Method in class org.apache.pig.backend.local.datastorage.LocalFile
 
sopen() - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
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
 
spawnChildWalker(P) - Method in class org.apache.pig.impl.plan.DependencyOrderWalker
 
spawnChildWalker(P) - Method in class org.apache.pig.impl.plan.DependencyOrderWalkerWOSeenChk
 
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(P) - Method in class org.apache.pig.pen.util.PreOrderDepthFirstWalker
 
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.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 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.
SpillableMemoryManager() - Constructor for class org.apache.pig.impl.util.SpillableMemoryManager
 
spillTupleContents(Tuple, String) - Static method in class org.apache.pig.data.DataType
Purely for debugging
splittable - Variable in class org.apache.pig.impl.logicalLayer.LOLoad
 
StandAloneParser - Class in org.apache.pig
 
StandAloneParser() - Constructor for class org.apache.pig.StandAloneParser
 
start() - Method in class org.apache.pig.tools.timer.PerformanceTimer
Start the timer.
startBag - Static variable in class org.apache.pig.data.DefaultAbstractBag
 
status - Variable in class org.apache.pig.backend.hadoop.executionengine.HJob
 
status - Variable in class org.apache.pig.backend.local.executionengine.LocalJob
 
STATUS_EOP - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
 
STATUS_EOS - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
 
STATUS_ERR - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
 
STATUS_NULL - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
 
STATUS_OK - Static variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.POStatus
 
stdin - Variable in class org.apache.pig.impl.streaming.ExecutableManager
 
stop() - Method in class org.apache.pig.tools.timer.PerformanceTimer
Stop the timer.
store(DataBag, StoreFunc, PigContext) - Method in class org.apache.pig.impl.io.PigFile
 
store(String, String) - Method in class org.apache.pig.PigServer
Store an alias into a file
store(String, String, String) - Method in class org.apache.pig.PigServer
forces execution of query (and all queries from which it reads), in order to store result in file
StoreConfig - Class in org.apache.pig
A Class which will encapsulate metadata information that a OutputFormat (or possibly StoreFunc) may want to know about the data that needs to be stored.
StoreConfig(String, Schema) - Constructor for class org.apache.pig.StoreConfig
 
StoreFunc - Interface in org.apache.pig
This interface is used to implement functions to write records from a dataset.
stores - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
 
stores - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapReduce.Reduce
 
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.
StreamingCommand.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.
StreamingCommand.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.
StreamOptimizer - Class in org.apache.pig.impl.logicalLayer.optimizer
A visitor to optimize in the following scenario with streaming: Optimize when LOAD precedes STREAM and the loader class is the same as the serializer for the STREAM.
StreamOptimizer(LogicalPlan, String) - Constructor for class org.apache.pig.impl.logicalLayer.optimizer.StreamOptimizer
 
StringConcat - Class in org.apache.pig.builtin
Generates the concatenation of the first two fields of a tuple.
StringConcat() - Constructor for class org.apache.pig.builtin.StringConcat
 
stringifySchema(StringBuilder, Schema, byte) - Static method in class org.apache.pig.impl.logicalLayer.schema.Schema
 
StringMax - Class in org.apache.pig.builtin
Generates the max of the values of the first field of a tuple.
StringMax() - Constructor for class org.apache.pig.builtin.StringMax
 
StringMax.Final - Class in org.apache.pig.builtin
 
StringMax.Final() - Constructor for class org.apache.pig.builtin.StringMax.Final
 
StringMax.Initial - Class in org.apache.pig.builtin
 
StringMax.Initial() - Constructor for class org.apache.pig.builtin.StringMax.Initial
 
StringMax.Intermediate - Class in org.apache.pig.builtin
 
StringMax.Intermediate() - Constructor for class org.apache.pig.builtin.StringMax.Intermediate
 
StringMin - Class in org.apache.pig.builtin
Generates the min of the String values in the first field of a tuple.
StringMin() - Constructor for class org.apache.pig.builtin.StringMin
 
StringMin.Final - Class in org.apache.pig.builtin
 
StringMin.Final() - Constructor for class org.apache.pig.builtin.StringMin.Final
 
StringMin.Initial - Class in org.apache.pig.builtin
 
StringMin.Initial() - Constructor for class org.apache.pig.builtin.StringMin.Initial
 
StringMin.Intermediate - Class in org.apache.pig.builtin
 
StringMin.Intermediate() - Constructor for class org.apache.pig.builtin.StringMin.Intermediate
 
StringSize - Class in org.apache.pig.builtin
Generates the size of the first field of a tuple.
StringSize() - Constructor for class org.apache.pig.builtin.StringSize
 
STYLE_UNIX - Static variable in class org.apache.pig.impl.io.FileLocalizer
 
STYLE_WINDOWS - Static variable in class org.apache.pig.impl.io.FileLocalizer
 
submit(PhysicalPlan, String) - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Execute the physical plan in non-blocking mode
submit(PhysicalPlan, String) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
submit(PhysicalPlan, String) - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
substitute(String) - Method in class org.apache.pig.tools.parameters.PreprocessorContext
 
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
 
succeededStores - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.Launcher
 
sum(Tuple) - Static method in class org.apache.pig.builtin.AVG
 
sum(Tuple) - Static method in class org.apache.pig.builtin.COUNT
 
sum(Tuple) - Static method in class org.apache.pig.builtin.DoubleAvg
 
sum(Tuple) - Static method in class org.apache.pig.builtin.DoubleSum
 
sum(Tuple) - Static method in class org.apache.pig.builtin.FloatAvg
 
sum(Tuple) - Static method in class org.apache.pig.builtin.FloatSum
 
sum(Tuple) - Static method in class org.apache.pig.builtin.IntAvg
 
sum(Tuple) - Static method in class org.apache.pig.builtin.IntSum
 
sum(Tuple) - Static method in class org.apache.pig.builtin.LongAvg
 
sum(Tuple) - Static method in class org.apache.pig.builtin.LongSum
 
SUM - Class in org.apache.pig.builtin
Generates the sum of the values of the first field of a tuple.
SUM() - Constructor for class org.apache.pig.builtin.SUM
 
sum(Tuple) - Static method in class org.apache.pig.builtin.SUM
 
SUM.Final - Class in org.apache.pig.builtin
 
SUM.Final() - Constructor for class org.apache.pig.builtin.SUM.Final
 
SUM.Initial - Class in org.apache.pig.builtin
 
SUM.Initial() - Constructor for class org.apache.pig.builtin.SUM.Initial
 
SUM.Intermediate - Class in org.apache.pig.builtin
 
SUM.Intermediate() - Constructor for class org.apache.pig.builtin.SUM.Intermediate
 
sumDoubles(Tuple) - Static method in class org.apache.pig.builtin.FloatSum
 
sumDoubles(Tuple) - Static method in class org.apache.pig.builtin.SUM
 
sumLongs(Tuple) - Static method in class org.apache.pig.builtin.IntSum
 
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.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.POMultiQueryPackage
 
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.POPreCombinerLocalRearrange
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORead
 
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.local.executionengine.physicalLayer.counters.POCounter
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCogroup
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCross
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplit
 
supportsMultipleInputs() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplitOutput
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.BinaryExpressionOperator
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOBinCond
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOCast
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOConst
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOCross
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LODefine
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LODistinct
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOFilter
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOGenerate
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOMapLookup
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LORegexp
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOSplit
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOStore
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOStream
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOUnion
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.LOUserFunc
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.logicalLayer.UnaryExpressionOperator
 
supportsMultipleInputs() - Method in class org.apache.pig.impl.plan.Operator
Indicates whether this operator supports multiple inputs.
supportsMultipleInputs() - Method in class org.apache.pig.impl.plan.optimizer.RuleOperator
 
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.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.POMultiQueryPackage
 
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.POPreCombinerLocalRearrange
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORead
 
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.local.executionengine.physicalLayer.counters.POCounter
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCogroup
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCross
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplit
 
supportsMultipleOutputs() - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplitOutput
 
supportsMultipleOutputs() - Method in class org.apache.pig.impl.logicalLayer.ExpressionOperator
 
supportsMultipleOutputs() - Method in class org.apache.pig.impl.logicalLayer.LOConst
 
supportsMultipleOutputs() - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
 
supportsMultipleOutputs() - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 
supportsMultipleOutputs() - Method in class org.apache.pig.impl.logicalLayer.LOSplit
 
supportsMultipleOutputs() - Method in class org.apache.pig.impl.logicalLayer.LOStore
 
supportsMultipleOutputs() - Method in class org.apache.pig.impl.plan.Operator
Indicates whether this operator supports multiple outputs.
supportsMultipleOutputs() - Method in class org.apache.pig.impl.plan.optimizer.RuleOperator
 
swap(E, E) - Method in class org.apache.pig.impl.plan.OperatorPlan
Swap two operators in a plan.
switchGroupByPlanOp(LogicalOperator, LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
This does switch the mapping oldOp -> List of inner plans to newOp -> List of inner plans which is useful when there is a structural change in LogicalPlan
switchJoinColPlanOp(LogicalOperator, LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
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
 
systemElement() - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 

T

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
 
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
tearDown() - Method in class org.apache.pig.backend.local.executionengine.LocalPOStoreImpl
 
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.backend.local.datastorage.LocalSeekableInputStream
 
TextLoader - Class in org.apache.pig.builtin
This load function simply creates a tuple for each line of text that has a single field that contains the line of text.
TextLoader() - Constructor for class org.apache.pig.builtin.TextLoader
 
tf - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigMapBase
 
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
 
toArray() - Method in class org.apache.pig.impl.util.IdentityHashSet
 
toArray(T[]) - Method in class org.apache.pig.impl.util.IdentityHashSet
 
toBag(Object) - Static method in class org.apache.pig.data.DataType
If this object is a bag, return it as a bag.
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(Map<Object, 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(Integer) - Method in class org.apache.pig.builtin.TextLoader
 
toBytes(Long) - Method in class org.apache.pig.builtin.TextLoader
 
toBytes(Map<Object, 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(Map<Object, Object>) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toBytes(Tuple) - Method in class org.apache.pig.builtin.Utf8StorageConverter
 
toConfiguration(Properties) - Static method in class org.apache.pig.backend.hadoop.datastorage.ConfigurationUtil
 
toDelimitedString(String) - Method in class org.apache.pig.data.DefaultTuple
Write a tuple of atomic values into a string.
toDelimitedString(String) - Method in class org.apache.pig.data.TargetedTuple
 
toDelimitedString(String) - Method in interface org.apache.pig.data.Tuple
Write a tuple of atomic values into a string.
toDelimitedString(String) - Method in class org.apache.pig.pen.util.ExampleTuple
 
toDetailString() - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
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
If type of object is not known, use this method which in turns call toLong(object,type) after finding type.
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
If type of object is not known, use this method which in turns call toFloat(object,type) after finding type.
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
If type of object is not known, use this method, which internally calls toInteger(object,type)
TOKENIZE - Class in org.apache.pig.builtin
 
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
If type of object is not known, use this method which in turns call toLong(object,type) after finding type.
toMap(Object) - Static method in class org.apache.pig.data.DataType
If this object is a map, return it as a map.
TopLevelProjectFinder - Class in org.apache.pig.impl.logicalLayer
A visitor to track the top-level projection operators in a plan.
TopLevelProjectFinder(LogicalPlan) - Constructor for class org.apache.pig.impl.logicalLayer.TopLevelProjectFinder
 
toProperties(Configuration) - Static method in class org.apache.pig.backend.hadoop.datastorage.ConfigurationUtil
 
toString() - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
toString() - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.partitioners.DiscreteProbabilitySampleGenerator
 
toString() - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.MROperPlan
 
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.hbase.HBaseSlice
 
toString() - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
toString() - Method in class org.apache.pig.builtin.BinaryStorage
 
toString() - Method in class org.apache.pig.data.DataByteArray
 
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
If type of object is not known, use this method which in turns call toString(object,type) after finding type.
toString() - Method in class org.apache.pig.data.DefaultAbstractBag
Write the bag into a string.
toString() - Method in class org.apache.pig.data.DefaultTuple
 
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.FuncSpec
 
toString() - Method in class org.apache.pig.impl.io.FileSpec
 
toString() - Method in class org.apache.pig.impl.io.PigFile
 
toString() - Method in class org.apache.pig.impl.io.PigNullableWritable
 
toString() - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
 
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 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.optimizer.RuleOperator
 
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 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.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.StoreConfig
 
totalHadoopTimeSpent() - Method in class org.apache.pig.PigServer
 
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
 
transform(List<LogicalOperator>) - Method in class org.apache.pig.impl.logicalLayer.optimizer.ImplicitSplitInserter
 
transform(List<LogicalOperator>) - Method in class org.apache.pig.impl.logicalLayer.optimizer.OpLimitOptimizer
 
transform(List<LogicalOperator>) - Method in class org.apache.pig.impl.logicalLayer.optimizer.StreamOptimizer
 
transform(List<LogicalOperator>) - Method in class org.apache.pig.impl.logicalLayer.optimizer.TypeCastInserter
 
transform(List<O>) - Method in class org.apache.pig.impl.plan.optimizer.Transformer
Transform the tree
Transformer<O extends Operator,P extends OperatorPlan<O>> - Class in org.apache.pig.impl.plan.optimizer
Transformer represents one tranform that the optimizer can apply to a graph.
Transformer(P, PlanWalker<O, P>) - Constructor for class org.apache.pig.impl.plan.optimizer.Transformer
 
triggerDeleteOnFail() - Static method in class org.apache.pig.impl.io.FileLocalizer
 
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.
trueRef - Variable in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.expressionOperators.BinaryComparisonOperator
 
TUPLE - Static variable in class org.apache.pig.data.DataType
 
Tuple - Interface in org.apache.pig.data
An ordered list of Data.
tupleClass() - Method in class org.apache.pig.data.DefaultTupleFactory
 
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
 
TupleSize - Class in org.apache.pig.builtin
Generates the size of the first field of a tuple.
TupleSize() - Constructor for class org.apache.pig.builtin.TupleSize
 
type - Variable in class org.apache.pig.impl.logicalLayer.schema.Schema.FieldSchema
Datatype, using codes from DataType.
TypeCastInserter - Class in org.apache.pig.impl.logicalLayer.optimizer
A visitor to discover if any schema has been specified for a file being loaded.
TypeCastInserter(LogicalPlan, String) - Constructor for class org.apache.pig.impl.logicalLayer.optimizer.TypeCastInserter
 
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(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.
TypeCheckingValidator - Class in org.apache.pig.impl.logicalLayer.validators
 
TypeCheckingValidator() - Constructor for class org.apache.pig.impl.logicalLayer.validators.TypeCheckingValidator
 
TypeCheckingVisitor - Class in org.apache.pig.impl.logicalLayer.validators
Visitor for type checking.
TypeCheckingVisitor(LogicalPlan, CompilationMessageCollector) - Constructor for class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 

U

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
 
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
 
UDFs - Variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
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
 
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
 
UnaryExpressionOperator - Class in org.apache.pig.impl.logicalLayer
This abstract class represents the logical Unary Expression Operator The unary operator has an operand and an operator.
UnaryExpressionOperator(LogicalPlan, OperatorKey, int) - Constructor for class org.apache.pig.impl.logicalLayer.UnaryExpressionOperator
 
UnaryExpressionOperator(LogicalPlan, OperatorKey) - Constructor for class org.apache.pig.impl.logicalLayer.UnaryExpressionOperator
 
union(Tuple, Tuple) - Method in class org.apache.pig.impl.util.LineageTracer
 
union(Tuple, Tuple) - Method in class org.apache.pig.pen.util.LineageTracer
 
UNKNOWN - Static variable in class org.apache.pig.data.DataType
 
unsetFieldSchema() - Method in class org.apache.pig.impl.logicalLayer.ExpressionOperator
Unset the field schema as if it had not been calculated.
unsetSchema() - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
unsetSchema() - Method in class org.apache.pig.impl.logicalLayer.LOFilter
 
unsetSchema() - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
unsetSchema() - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
unsetSchema() - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Unset the schema as if it had not been calculated.
unsetSchema() - Method in class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
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 interface org.apache.pig.backend.executionengine.ExecPhysicalPlan
Some properties of the job may be changed, say the priority...
updateConfiguration(Properties) - Method in interface org.apache.pig.backend.executionengine.ExecutionEngine
Provides a way to dynamically change configuration parameters at the Execution Engine level.
updateConfiguration(Properties) - Method in class org.apache.pig.backend.hadoop.datastorage.HDataStorage
 
updateConfiguration(Properties) - Method in class org.apache.pig.backend.hadoop.datastorage.HPath
 
updateConfiguration(Properties) - Method in class org.apache.pig.backend.hadoop.executionengine.HExecutionEngine
 
updateConfiguration(Properties) - Method in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
updateConfiguration(Properties) - Method in class org.apache.pig.backend.local.datastorage.LocalPath
 
updateConfiguration(Properties) - Method in class org.apache.pig.backend.local.executionengine.LocalExecutionEngine
 
usage() - Static method in class org.apache.pig.Main
 
USED_BYTES_KEY - Static variable in interface org.apache.pig.backend.datastorage.DataStorage
 
USER_COMPARATOR_MARKER - Static variable in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MRCompiler
 
USER_ENVIRONMENT - Static variable in exception org.apache.pig.PigException
 
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
 

V

validate(DataStorage, String) - Method in class org.apache.pig.backend.executionengine.PigSlicer
 
validate(DataStorage, String) - Method in class org.apache.pig.backend.hadoop.hbase.HBaseStorage
 
validate(LogicalPlan, CompilationMessageCollector) - Method in class org.apache.pig.impl.logicalLayer.validators.InputOutputFileValidator
 
validate(LogicalPlan, CompilationMessageCollector) - Method in class org.apache.pig.impl.logicalLayer.validators.LogicalPlanValidationExecutor
 
validate(LogicalPlan, CompilationMessageCollector) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingValidator
 
validate(P, CompilationMessageCollector) - Method in interface org.apache.pig.impl.plan.PlanValidationExecutor
 
validate(P, CompilationMessageCollector) - Method in class org.apache.pig.impl.plan.PlanValidator
If there are errors during validation, all of the errors have to be collected in the supplied messageCollector.
validate(PlanVisitor<O, P>, CompilationMessageCollector) - Method in class org.apache.pig.impl.plan.PlanValidator
This convenient method is used when: - if an exception being thrown from the current validation logic indicates that the whole validation pipeline should stop.
validate(DataStorage, String) - Method in interface org.apache.pig.Slicer
Checks that location is parsable by this Slicer, and that if the DataStorage is used by the Slicer, it's readable from there.
validateInput(JobConf) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigInputFormat
 
validatePigProperties(Properties) - Static method in class org.apache.pig.impl.util.ConfigurationValidator
All pig configurations should be validated in here before use
validateSkipCollectException(PlanVisitor<O, P>, CompilationMessageCollector) - Method in class org.apache.pig.impl.plan.PlanValidator
This convenient method is used when: - if an exception being thrown from the current validation logic indicates that the whole validation pipeline should stop.
validateTolerateException(PlanVisitor<O, P>, CompilationMessageCollector) - Method in class org.apache.pig.impl.plan.PlanValidator
This convenient method is used when: - if an exception being thrown from the current validation logic indicates that the whole validation pipeline should keep going by continuing with the next validation logic in the pipeline (skip the rest of the current logic)
ValidatingInputFileSpec - Class in org.apache.pig.impl.io
Creates a Slicer using its funcSpec in its construction and checks that it's valid.
ValidatingInputFileSpec(FileSpec, DataStorage) - Constructor for class org.apache.pig.impl.io.ValidatingInputFileSpec
 
ValidatingInputFileSpec(String, String, PigContext) - Constructor for class org.apache.pig.impl.io.ValidatingInputFileSpec
If the ExecType of context is LOCAL, validation is not performed.
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.ExecType
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.optimizer.Rule.WalkerAlgo
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.pig.impl.plan.optimizer.RuleOperator.NodeType
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.PigWarning
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.
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.ExecType
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.optimizer.Rule.WalkerAlgo
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.optimizer.RuleOperator.NodeType
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.MultiMap
Get a single collection of all the values in the map.
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.tools.cmdline.CmdLineParser.ValueExpected
Returns an array containing the constants of this enum type, in the order they are declared.
visit(MROpPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.MapReduceOper
 
visit(PlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.DotMRPrinter.InnerOperator
 
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(LOGreaterThan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOLesserThan) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOGreaterThanEqual) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOLesserThanEqual) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOEqual) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LONotEqual) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LORegexp) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOAdd) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOSubtract) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOMultiply) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LODivide) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOMod) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOAnd) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOOr) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LONot) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOCross) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOCogroup) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOFRJoin) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
Create the inner plans used to configure the Local Rearrange operators(ppLists) Extract the keytypes and create the POFRJoin operator.
visit(LOFilter) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOStream) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOProject) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOForEach) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOSort) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LODistinct) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOSplit) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOUserFunc) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOLoad) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOStore) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOConst) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOBinCond) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LONegative) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOIsNull) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOMapLookup) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOCast) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOLimit) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(LOUnion) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.LogToPhyTranslationVisitor
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.PhysicalOperator
 
visit() - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POCombinerPackage
 
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.POJoinPackage
 
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.POLocalRearrangeForIllustrate
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.POMultiQueryPackage
 
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.POPreCombinerLocalRearrange
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.relationalOperators.PORead
 
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.local.executionengine.physicalLayer.counters.POCounter
 
visit(LOCogroup) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.LocalLogToPhyTranslationVisitor
 
visit(LOSplit) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.LocalLogToPhyTranslationVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.LocalLogToPhyTranslationVisitor
 
visit(LOStream) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.LocalLogToPhyTranslationVisitor
 
visit(LOCross) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.LocalLogToPhyTranslationVisitor
 
visit(LOStore) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.LocalLogToPhyTranslationVisitor
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCogroup
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POCross
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplit
 
visit(PhyPlanVisitor) - Method in class org.apache.pig.backend.local.executionengine.physicalLayer.relationalOperators.POSplitOutput
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.BinaryExpressionOperator
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOAdd
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOAnd
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOBinCond
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOCast
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOCogroup
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOConst
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOCross
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LODefine
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LODistinct
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LODivide
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOEqual
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOFilter
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOForEach
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOFRJoin
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOGenerate
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LogicalOperator
Visit this node with the provided visitor.
visit(BinaryExpressionOperator) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOAdd) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOAnd) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOBinCond) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOCast) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOCogroup) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOConst) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOCross) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LODistinct) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LODivide) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOEqual) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOFilter) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOForEach) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOGenerate) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOGreaterThan) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOGreaterThanEqual) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOIsNull) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOLesserThan) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOLesserThanEqual) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOLimit) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOLoad) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOMapLookup) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOMod) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOMultiply) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LONegative) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LONot) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LONotEqual) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOOr) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOProject) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LORegexp) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOSort) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOSplit) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOSplitOutput) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOStore) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOStream) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOSubtract) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOUnion) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOUserFunc) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(UnaryExpressionOperator) - Method in class org.apache.pig.impl.logicalLayer.LogicalPlanCloneHelper
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOGreaterThan
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOGreaterThanEqual
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOIsNull
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOLesserThan
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOLesserThanEqual
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOLimit
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOLoad
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOMapLookup
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOMod
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOMultiply
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LONegative
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LONot
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LONotEqual
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOOr
 
visit() - Method in class org.apache.pig.impl.logicalLayer.LOPrinter
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOProject
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LORegexp
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOSort
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOSplit
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOSplitOutput
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOStore
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOStream
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOSubtract
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOUnion
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.LOUserFunc
 
visit(LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(ExpressionOperator) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(BinaryExpressionOperator) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(UnaryExpressionOperator) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOCogroup) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOFRJoin) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOForEach) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOSort) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOLimit) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOStream) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOFilter) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOSplit) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOGenerate) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOUserFunc) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
Iterate over each expression that is part of the function argument list
visit(LOBinCond) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOCast) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LORegexp) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOLoad) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOStore) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOConst) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOUnion) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LODistinct) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOCross) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOProject) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOGreaterThan) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOLesserThan) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOGreaterThanEqual) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOLesserThanEqual) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOEqual) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LONotEqual) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOAdd) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOSubtract) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOMultiply) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LODivide) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOMod) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LONegative) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOMapLookup) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOAnd) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOOr) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LONot) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(LOIsNull) - Method in class org.apache.pig.impl.logicalLayer.LOVisitor
 
visit(BinaryExpressionOperator) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(UnaryExpressionOperator) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOCogroup) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOSort) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOLimit) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOFilter) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOSplit) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOForEach) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOUserFunc) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
Iterate over each expression that is part of the function argument list
visit(LOBinCond) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOCast) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LORegexp) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOLoad) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOStore) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOConst) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOUnion) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOSplitOutput) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LODistinct) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOCross) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(LOProject) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaCalculator
 
visit(BinaryExpressionOperator) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(UnaryExpressionOperator) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOCogroup) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOSort) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOLimit) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOFilter) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOSplit) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOForEach) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOUserFunc) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
Iterate over each expression that is part of the function argument list
visit(LOBinCond) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOCast) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LORegexp) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOLoad) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOStore) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOConst) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOUnion) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOSplitOutput) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LODistinct) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOCross) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOProject) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOFRJoin) - Method in class org.apache.pig.impl.logicalLayer.optimizer.SchemaRemover
 
visit(LOAdd) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOAnd) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOBinCond) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOCast) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOCogroup) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOFRJoin) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOConst) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOCross) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LODistinct) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LODivide) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOEqual) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOFilter) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOForEach) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOGreaterThan) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOGreaterThanEqual) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOIsNull) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOLesserThan) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOLesserThanEqual) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOLimit) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOLoad) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOMapLookup) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOMod) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOMultiply) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LONegative) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LONot) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LONotEqual) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOOr) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOProject) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LORegexp) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOSort) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOSplit) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOSplitOutput) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOStore) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOSubtract) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOUnion) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOUserFunc) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOStream) - Method in class org.apache.pig.impl.logicalLayer.PlanSetter
 
visit(LOCogroup) - Method in class org.apache.pig.impl.logicalLayer.ProjectStarTranslator
 
visit(LOFRJoin) - Method in class org.apache.pig.impl.logicalLayer.ProjectStarTranslator
 
visit(LOForEach) - Method in class org.apache.pig.impl.logicalLayer.ProjectStarTranslator
 
visit(LOSort) - Method in class org.apache.pig.impl.logicalLayer.ProjectStarTranslator
 
visit(LOProject) - Method in class org.apache.pig.impl.logicalLayer.RemoveRedundantOperators
 
visit(LODistinct) - Method in class org.apache.pig.impl.logicalLayer.TopLevelProjectFinder
 
visit(LOFilter) - Method in class org.apache.pig.impl.logicalLayer.TopLevelProjectFinder
 
visit(LOForEach) - Method in class org.apache.pig.impl.logicalLayer.TopLevelProjectFinder
 
visit(LOSort) - Method in class org.apache.pig.impl.logicalLayer.TopLevelProjectFinder
 
visit(LOProject) - Method in class org.apache.pig.impl.logicalLayer.TopLevelProjectFinder
 
visit(LOVisitor) - Method in class org.apache.pig.impl.logicalLayer.UnaryExpressionOperator
 
visit(LOStore) - Method in class org.apache.pig.impl.logicalLayer.validators.InputOutputFileVisitor
The logic here is just to check that the file(s) do not exist
visit(ExpressionOperator) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LogicalOperator) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOProject) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOConst) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
LOConst.
visit(LOMapLookup) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LORegexp) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
LORegexp expects CharArray as input Itself always returns Boolean
visit(LOAnd) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOOr) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOMultiply) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LODivide) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOAdd) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOSubtract) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOGreaterThan) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOGreaterThanEqual) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOLesserThan) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOLesserThanEqual) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOEqual) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LONotEqual) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOMod) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LONegative) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LONot) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOIsNull) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(UnaryExpressionOperator) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
Currently, there are two unaryOps: Neg and Not.
visit(LOUserFunc) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOBinCond) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
For Bincond, lhsOp and rhsOp must have the same output type or both sides have to be number
visit(LOCast) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
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 or chararray) to (bytearray or chararray) is ok For Composite Types: Recursively traverse the schemas till you get a basic type
visit(LOUnion) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOSplitOutput) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LODistinct) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
LODistinct, output schema should be the same as input
visit(LOLimit) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOCross) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
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.impl.logicalLayer.validators.TypeCheckingVisitor
The schema of sort output will be the same as sort input.
visit(LOFilter) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
The schema of filter output will be the same as filter input
visit(LOSplit) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
The schema of split output will be the same as split input
visit(LOFRJoin) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
Mimics the type checking of LOCogroup
visit(LOCogroup) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
COGroup All group by cols from all inputs have to be of the same type
visit(LOForEach) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
Output schema of LOForEach is a tuple schma which is the output of all inner plans Flatten also has to be taken care on in here
visit(LOLoad) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
visit(LOStore) - Method in class org.apache.pig.impl.logicalLayer.validators.TypeCheckingVisitor
 
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.optimizer.CommonNodeFinder
 
visit(RuleOperator) - Method in class org.apache.pig.impl.plan.optimizer.CommonNodeFinder
 
visit(RulePlanVisitor) - Method in class org.apache.pig.impl.plan.optimizer.RuleOperator
Visit this node with the provided visitor.
visit() - Method in class org.apache.pig.impl.plan.optimizer.RulePlanPrinter
 
visit(RuleOperator) - Method in class org.apache.pig.impl.plan.optimizer.RulePlanVisitor
 
visit() - Method in class org.apache.pig.impl.plan.PlanPrinter
 
visit() - Method in class org.apache.pig.impl.plan.PlanVisitor
Entry point for visiting the plan.
visit(LOCogroup) - 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(LOCogroup) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
visit(LOCross) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
visit(LODistinct) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
visit(LOFilter) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
visit(LOForEach) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
visit(LOLoad) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
visit(LOSplit) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
visit(LOStore) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
visit(LOUnion) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
visit(LOLimit) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
visit(LOSort) - Method in class org.apache.pig.pen.DerivedDataVisitor
 
visit(LOCogroup) - 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(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(LOUnion) - Method in class org.apache.pig.pen.LineageTrimmingVisitor
 
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
 
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
 
visitCast(POCast) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitCast(POCast) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitCogroup(POCogroup) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitCogroup(POCogroup) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
visitCombinerPackage(POCombinerPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitCombinerPackage(POCombinerPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
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
 
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
 
visitCross(POCross) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitCross(POCross) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
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
 
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
 
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
 
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
 
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
 
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
 
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
 
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
 
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
 
visitJoinPackage(POJoinPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitJoinPackage(POJoinPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
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
 
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
 
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
 
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.physicalLayer.plans.PhyPlanVisitor
 
visitLocalRearrange(POLocalRearrange) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PlanPrinter
 
visitLocalRearrangeForIllustrate(POLocalRearrangeForIllustrate) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitLocalRearrangeForIllustrate(POLocalRearrangeForIllustrate) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
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
 
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
 
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.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.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.MRStreamHandler
 
visitMROp(MapReduceOper) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.plans.POPackageAnnotator
 
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
 
visitMultiQueryPackage(POMultiQueryPackage) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
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
 
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
 
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
 
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
 
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(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(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(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
 
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.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
 
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
 
visitRead(PORead) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PhyPlanSetter
 
visitRead(PORead) - Method in class org.apache.pig.backend.hadoop.executionengine.physicalLayer.plans.PhyPlanVisitor
 
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
 
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
 
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.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.physicalLayer.plans.PhyPlanVisitor
 
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
 
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.physicalLayer.plans.PhyPlanVisitor
 
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
 
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
 
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.UDFFinder
 
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
 

W

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.DependencyOrderWalkerWOSeenChk
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<O, P>) - Method in class org.apache.pig.pen.util.DependencyOrderLimitedWalker
 
walk(PlanVisitor<O, P>) - 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, Exception) - Method in class org.apache.pig.data.DefaultAbstractBag
 
warn(String, Enum) - Method in class org.apache.pig.EvalFunc
 
warn(Object, String, PigWarning, Log) - Static method in class org.apache.pig.impl.util.LogUtils
 
WEIGHTED_PARTS - Static variable in class org.apache.pig.impl.builtin.FindQuantiles
 
weightedParts - Static 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
 
workingDir - Variable in class org.apache.pig.backend.local.datastorage.LocalDataStorage
 
wrap(Throwable) - Static method in class org.apache.pig.impl.util.WrappedIOException
 
wrap(String, Throwable) - Static method in class org.apache.pig.impl.util.WrappedIOException
 
WrappedIOException - Class in org.apache.pig.impl.util
FIXME PIG-80 replace this code when pig will be java 6 compliant with "throw new IOException(e);"
WrappedIOException() - Constructor for class org.apache.pig.impl.util.WrappedIOException
 
write(int) - Method in class org.apache.pig.backend.datastorage.ImmutableOutputStream
 
write(DataOutput) - Method in class org.apache.pig.backend.executionengine.PigSlice
 
write(DataOutput) - Method in class org.apache.pig.backend.hadoop.DoubleWritable
 
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(DataOutput) - Method in class org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.SliceWrapper
 
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.NonSpillableDataBag
Write a bag's contents to disk.
write(DataOutput) - Method in class org.apache.pig.data.ReadOnceBag
 
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.impl.io.PigNullableWritable
 
write(DataOutput) - Method in class org.apache.pig.pen.util.ExampleTuple
 
writeDatum(DataOutput, Object) - Static method in class org.apache.pig.data.DataReaderWriter
 
writeLog(Throwable, String, Log, boolean) - 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
 

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

Copyright © ${year} The Apache Software Foundation