public class BaseStep extends Object implements VariableSpace, StepInterface, LoggingObjectInterface, ExtensionDataInterface
The implementing class can rely mostly on the base class, and has only three important methods it implements itself. The three methods implement the step lifecycle during transformation execution: initialization, row processing, and clean-up.
public boolean init(...)
Every step is given the opportunity to do one-time initialization tasks like opening files or establishing database connections. For any steps derived from BaseStep it is mandatory that super.init() is called to ensure correct behavior. The method must return true in case the step initialized correctly, it must returned false if there was an initialization error. PDI will abort the execution of a transformation in case any step returns false upon initialization.
public boolean processRow(...)
A typical implementation queries for incoming input rows by calling getRow(), which blocks and returns a row object or null in case there is no more input. If there was an input row, the step does the necessary row processing and calls putRow() to pass the row on to the next step. If there are no more rows, the step must call setOutputDone() and return false.
Formally the method must conform to the following rules:
public void dispose(...)
Steps are required to deallocate resources allocated during init() or subsequent row processing. This typically means to clear all fields of the StepDataInterface object, and to ensure that all open files or connections are properly closed. For any steps derived from BaseStep it is mandatory that super.dispose() is called to ensure correct deallocation.
Modifier and Type | Field and Description |
---|---|
protected long |
deadLockCounter
Keeps track of the number of rows read for input deadlock verification.
|
protected Map<String,Object> |
extensionDataMap |
boolean |
first
if true then the row being processed is the first row
|
long |
linesInput
Deprecated.
|
long |
linesOutput
Deprecated.
|
long |
linesRead
Deprecated.
|
long |
linesRejected
Deprecated.
|
long |
linesSkipped
Deprecated.
|
long |
linesUpdated
Deprecated.
|
long |
linesWritten
Deprecated.
|
protected LogChannelInterface |
log |
protected org.pentaho.metastore.api.IMetaStore |
metaStore
The metastore that the step uses to load external elements from
|
protected Repository |
repository
The repository used by the step to load and reference Kettle objects with at runtime
|
protected List<RowListener> |
rowListeners
The list of RowListener interfaces
|
protected AtomicBoolean |
safeStopped |
boolean |
terminator |
List<Object[]> |
terminator_rows |
protected VariableSpace |
variables |
Constructor and Description |
---|
BaseStep(StepMeta stepMeta,
StepDataInterface stepDataInterface,
int copyNr,
TransMeta transMeta,
Trans trans)
This is the base step that forms that basis for all steps.
|
Modifier and Type | Method and Description |
---|---|
void |
addResultFile(ResultFile resultFile)
Adds the result file.
|
void |
addRowListener(RowListener rowListener)
Add a rowlistener to the step allowing you to inspect (or manipulate, be careful) the rows coming in or exiting the
step.
|
void |
addRowSetToInputRowSets(RowSet rowSet) |
void |
addRowSetToOutputRowSets(RowSet rowSet) |
void |
addStepListener(StepListener stepListener)
Attach a step listener to be notified when a step arrives in a certain state.
|
void |
batchComplete()
Calling this method will alert the step that we finished passing a batch of records to the step.
|
RowMetaAndData |
buildLog(String sname,
int copynr,
long lines_read,
long lines_written,
long lines_updated,
long lines_skipped,
long errors,
Date start_date,
Date end_date)
Builds the log.
|
boolean |
canProcessOneRow()
This method checks if the step is capable of processing at least one row.
|
protected boolean |
checkFeedback(long lines)
Check feedback.
|
void |
cleanup()
Call this method typically, after ALL the slave transformations in a clustered run have finished.
|
protected void |
clearInputRowSets() |
protected void |
clearOutputRowSets() |
static void |
closeQuietly(Closeable cl)
Close quietly.
|
void |
copyVariablesFrom(VariableSpace space) |
long |
decrementLinesRead()
Decrements the number of lines read from previous steps by one
|
long |
decrementLinesWritten()
Decrements the number of lines written to next steps by one
|
void |
dispatch()
This method finds the surrounding steps and rowsets for this base step.
|
void |
dispose(StepMetaInterface smi,
StepDataInterface sdi)
Dispose of this step: close files, empty logs, etc.
|
String |
environmentSubstitute(String aString) |
String[] |
environmentSubstitute(String[] aString) |
String |
fieldSubstitute(String aString,
RowMetaInterface rowMeta,
Object[] rowData) |
RowSet |
findInputRowSet(String sourceStep)
Find input row set.
|
RowSet |
findInputRowSet(String from,
int fromcopy,
String to,
int tocopy)
Find input row set.
|
RowSet |
findOutputRowSet(String targetStep)
Find output row set.
|
RowSet |
findOutputRowSet(String from,
int fromcopy,
String to,
int tocopy)
Find an output rowset in a running transformation.
|
boolean |
getBooleanValueOfVariable(String variableName,
boolean defaultValue) |
int |
getClusterSize()
Returns the cluster size.
|
String |
getContainerObjectId()
Returns the container object ID.
|
int |
getCopy() |
int |
getCurrentInputRowSetNr() |
int |
getCurrentOutputRowSetNr() |
Trans |
getDispatcher()
Gets the dispatcher.
|
RowMetaInterface |
getErrorRowMeta() |
long |
getErrors()
Get the number of errors
|
Map<String,Object> |
getExtensionDataMap() |
String |
getFilename() |
protected RowSet |
getFirstInputRowSet() |
RowMetaInterface |
getInputRowMeta() |
List<RowSet> |
getInputRowSets() |
long |
getLinesInput() |
long |
getLinesOutput() |
long |
getLinesRead() |
long |
getLinesRejected() |
long |
getLinesSkipped() |
long |
getLinesUpdated() |
long |
getLinesWritten() |
LogChannelInterface |
getLogChannel() |
String |
getLogChannelId() |
static RowMetaInterface |
getLogFields(String comm)
Gets the log fields.
|
LogLevel |
getLogLevel() |
org.pentaho.metastore.api.IMetaStore |
getMetaStore() |
int |
getNextClassNr()
Gets the next class nr.
|
String |
getObjectCopy() |
ObjectId |
getObjectId() |
String |
getObjectName() |
ObjectRevision |
getObjectRevision() |
LoggingObjectType |
getObjectType() |
List<RowSet> |
getOutputRowSets() |
LoggingObjectInterface |
getParent() |
VariableSpace |
getParentVariableSpace() |
String |
getPartitionID() |
Map<String,BlockingRowSet> |
getPartitionTargets() |
RowMetaInterface |
getPreviewRowMeta() |
long |
getProcessed() |
Date |
getRegistrationDate()
Returns the registration date
|
List<RemoteStep> |
getRemoteInputSteps()
Gets the remote input steps.
|
List<RemoteStep> |
getRemoteOutputSteps()
Gets the remote output steps.
|
int |
getRepartitioning() |
Repository |
getRepository() |
RepositoryDirectory |
getRepositoryDirectory() |
Map<String,ResultFile> |
getResultFiles() |
Object[] |
getRow()
In case of getRow, we receive data from previous steps through the input rowset.
|
Object[] |
getRowFrom(RowSet rowSet)
Gets the row from.
|
RowHandler |
getRowHandler() |
List<RowListener> |
getRowListeners() |
long |
getRuntime() |
List<ServerSocket> |
getServerSockets()
Returns the serverSockets.
|
int |
getSlaveNr()
Returns the unique slave number in the cluster.
|
SocketRepository |
getSocketRepository()
Retutns the socket repository.
|
BaseStepData.StepExecutionStatus |
getStatus() |
String |
getStatusDescription()
Gets the status description.
|
StepDataInterface |
getStepDataInterface() |
String |
getStepID() |
List<StepListener> |
getStepListeners()
Returns the step listeners.
|
StepMeta |
getStepMeta() |
StepMetaInterface |
getStepMetaInterface() |
String |
getStepname()
Get the name of the step.
|
Trans |
getTrans() |
TransMeta |
getTransMeta() |
String |
getTypeId()
Returns the step ID via the getStepID() method call.
|
int |
getUniqueStepCountAcrossSlaves()
Returns the number of unique steps across all slave servers.
|
int |
getUniqueStepNrAcrossSlaves()
Returns a unique step number across all slave servers: slaveNr * nrCopies + copyNr.
|
String |
getVariable(String variableName) |
String |
getVariable(String variableName,
String defaultValue) |
Object[] |
handleGetRowFrom(RowSet rowSet) |
void |
handlePutRowTo(RowMetaInterface rowMeta,
Object[] row,
RowSet rowSet) |
void |
identifyErrorOutput()
To be used to flag an error output channel of a step prior to execution for performance reasons.
|
long |
incrementLinesInput()
Increments the number of lines read from an input source: database, file, socket, etc.
|
long |
incrementLinesOutput()
Increments the number of lines written to an output target: database, file, socket, etc.
|
long |
incrementLinesRead()
Increments the number of lines read from previous steps by one
|
long |
incrementLinesRejected()
Increments the number of lines rejected to an error handling step
|
long |
incrementLinesSkipped()
Increments the number of lines skipped
|
long |
incrementLinesUpdated()
Increments the number of lines updated in an output target: database, file, socket, etc.
|
long |
incrementLinesWritten()
Increments the number of lines written to next steps by one
|
boolean |
init(StepMetaInterface smi,
StepDataInterface sdi)
Initialize and do work where other steps need to wait for...
|
void |
initBeforeStart()
This method is executed by Trans right before the threads start and right after initialization.
|
void |
initializeVariablesFrom(VariableSpace parent) |
void |
injectVariables(Map<String,String> prop) |
boolean |
isBasic()
Checks if is basic.
|
boolean |
isDebug()
Checks if is debug.
|
boolean |
isDetailed()
Checks if is detailed.
|
boolean |
isDistributed() |
boolean |
isForcingSeparateLogging() |
boolean |
isGatheringMetrics() |
boolean |
isInitialising()
Checks if is initialising.
|
boolean |
isMapping() |
boolean |
isPartitioned() |
boolean |
isPaused() |
boolean |
isRowLevel()
Checks if is row level.
|
boolean |
isRunning() |
boolean |
isSafeStopped() |
boolean |
isStopped() |
boolean |
isUsingThreadPriorityManagment()
Retusn true if we are actively managing priorities of step threads.
|
String[] |
listVariables() |
void |
logBasic(String message)
Log basic.
|
void |
logBasic(String message,
Object... arguments)
Log basic.
|
void |
logDebug(String message)
Log debug.
|
void |
logDebug(String message,
Object... arguments)
Log debug.
|
void |
logDetailed(String message)
Log detailed.
|
void |
logDetailed(String message,
Object... arguments)
Log detailed.
|
void |
logError(String message)
Log error.
|
void |
logError(String message,
Object... arguments)
Log error.
|
void |
logError(String message,
Throwable e)
Log error.
|
void |
logMinimal(String message)
Log minimal.
|
void |
logMinimal(String message,
Object... arguments)
Log minimal.
|
void |
logRowlevel(String message)
Log rowlevel.
|
void |
logRowlevel(String message,
Object... arguments)
Log rowlevel.
|
void |
logSummary()
Log summary.
|
void |
markStart()
Mark the start time of the step.
|
void |
markStop()
Mark the end time of the step.
|
protected void |
openRemoteInputStepSocketsOnce()
Opens socket connections to the remote input steps of this step.
|
protected void |
openRemoteOutputStepSocketsOnce()
Opens socket connections to the remote output steps of this step.
|
boolean |
outputIsDone()
Output is done.
|
void |
pauseRunning()
Pause a running step
|
boolean |
processRow(StepMetaInterface smi,
StepDataInterface sdi)
Perform the equivalent of processing one row.
|
void |
putError(RowMetaInterface rowMeta,
Object[] row,
long nrErrors,
String errorDescriptions,
String fieldNames,
String errorCodes)
Put error.
|
void |
putRow(RowMetaInterface rowMeta,
Object[] row)
putRow is used to copy a row, to the alternate rowset(s) This should get priority over everything else!
(synchronized) If distribute is true, a row is copied only once to the output rowsets, otherwise copies are sent to
each rowset!
|
void |
putRowTo(RowMetaInterface rowMeta,
Object[] row,
RowSet rowSet)
putRowTo is used to put a row in a certain specific RowSet.
|
void |
removeRowListener(RowListener rowListener)
Remove a rowlistener from this step.
|
void |
resumeRunning()
Resume a running step
|
int |
rowsetInputSize() |
int |
rowsetOutputSize() |
protected void |
safeModeChecking(RowMetaInterface row)
Safe mode checking.
|
static void |
safeModeChecking(RowMetaInterface referenceRowMeta,
RowMetaInterface rowMeta)
Safe mode checking.
|
void |
setCarteObjectId(String containerObjectId)
Sets the container object ID.
|
void |
setCopy(int cop)
Sets the copy.
|
void |
setCurrentInputRowSetNr(int index) |
void |
setCurrentOutputRowSetNr(int index) |
void |
setDistributed(boolean distributed) |
void |
setErrorRowMeta(RowMetaInterface errorRowMeta) |
void |
setErrors(long e)
Sets the number of errors
|
void |
setForcingSeparateLogging(boolean forcingSeparateLogging) |
void |
setGatheringMetrics(boolean gatheringMetrics) |
void |
setInputRowMeta(RowMetaInterface rowMeta) |
void |
setInputRowSets(List<RowSet> inputRowSets) |
void |
setInternalVariables()
Sets the internal variables.
|
void |
setLinesInput(long newLinesInputValue) |
void |
setLinesOutput(long newLinesOutputValue) |
void |
setLinesRead(long newLinesReadValue) |
void |
setLinesRejected(long newLinesRejectedValue) |
void |
setLinesSkipped(long newLinesSkippedValue) |
void |
setLinesUpdated(long newLinesUpdatedValue) |
void |
setLinesWritten(long newLinesWrittenValue) |
void |
setLogLevel(LogLevel logLevel)
Sets the log level.
|
void |
setMetaStore(org.pentaho.metastore.api.IMetaStore metaStore)
Pass along the metastore to use when loading external elements at runtime.
|
void |
setOutputDone()
Signal output done to destination steps
|
void |
setOutputRowSets(List<RowSet> outputRowSets) |
void |
setParentVariableSpace(VariableSpace parent) |
void |
setPartitioned(boolean partitioned) |
void |
setPartitionID(String partitionID) |
void |
setPartitionTargets(Map<String,BlockingRowSet> partitionTargets) |
void |
setPaused(AtomicBoolean paused)
Sets the paused.
|
void |
setPaused(boolean paused)
Sets the paused.
|
void |
setPreviewRowMeta(RowMetaInterface previewRowMeta) |
void |
setRepartitioning(int repartitioning) |
void |
setRepository(Repository repository) |
void |
setRowHandler(RowHandler rowHandler)
RowHandler controls how getRow/putRow are handled.
|
void |
setRunning(boolean running)
Flag the step as running or not
|
void |
setSafeStopped(boolean stopped) |
void |
setServerSockets(List<ServerSocket> serverSockets) |
void |
setSocketRepository(SocketRepository socketRepository)
Sets the socket repository.
|
void |
setStepDataInterface(StepDataInterface stepDataInterface) |
void |
setStepListeners(List<StepListener> stepListeners)
Sets the step listeners.
|
void |
setStepMeta(StepMeta stepMeta) |
void |
setStepMetaInterface(StepMetaInterface stepMetaInterface) |
void |
setStepname(String stepname)
Sets the stepname.
|
void |
setStopped(boolean stopped) |
void |
setTransMeta(TransMeta transMeta) |
void |
setUsingThreadPriorityManagment(boolean usingThreadPriorityManagment)
Set to true to actively manage priorities of step threads.
|
void |
setVariable(String variableName,
String variableValue) |
void |
shareVariablesWith(VariableSpace space) |
void |
stopAll()
Flags all rowsets as stopped/completed/finished.
|
void |
stopRunning()
Deprecated.
|
void |
stopRunning(StepMetaInterface stepMetaInterface,
StepDataInterface stepDataInterface)
Perform actions to stop a running step.
|
protected void |
swapFirstInputRowSetIfExists(String stepName) |
String |
toString() |
protected void |
verifyInputDeadLock()
- A step sees that it can't get a new row from input in the step.
|
protected void |
waitUntilTransformationIsStarted()
Wait until the transformation is completely running and all threads have been started.
|
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
subStatuses
protected VariableSpace variables
protected LogChannelInterface log
@Deprecated public long linesRead
getLinesRead()
, incrementLinesRead()
, or decrementLinesRead()
@Deprecated public long linesWritten
getLinesWritten()
, incrementLinesWritten()
, or decrementLinesWritten()
@Deprecated public long linesInput
getLinesInput()
or incrementLinesInput()
@Deprecated public long linesOutput
getLinesOutput()
or incrementLinesOutput()
@Deprecated public long linesUpdated
getLinesUpdated()
or incrementLinesUpdated()
@Deprecated public long linesSkipped
getLinesSkipped()
or incrementLinesSkipped()
@Deprecated public long linesRejected
getLinesRejected()
or incrementLinesRejected()
protected AtomicBoolean safeStopped
public boolean first
public boolean terminator
protected List<RowListener> rowListeners
protected long deadLockCounter
protected Repository repository
protected org.pentaho.metastore.api.IMetaStore metaStore
public BaseStep(StepMeta stepMeta, StepDataInterface stepDataInterface, int copyNr, TransMeta transMeta, Trans trans)
stepMeta
- The StepMeta object to run.stepDataInterface
- the data object to store temporary data, database connections, caches, result sets,
hashtables etc.copyNr
- The copynumber for this step.transMeta
- The TransInfo of which the step stepMeta is part of.trans
- The (running) transformation to obtain information shared among the steps.public boolean init(StepMetaInterface smi, StepDataInterface sdi)
StepInterface
init
in interface StepInterface
smi
- The metadata to work withsdi
- The data to initializepublic void dispose(StepMetaInterface smi, StepDataInterface sdi)
StepInterface
dispose
in interface StepInterface
smi
- The metadata to work withsdi
- The data to dispose ofpublic void cleanup()
StepInterface
cleanup
in interface StepInterface
public long getProcessed()
getProcessed
in interface StepInterface
public void setCopy(int cop)
cop
- the new copypublic int getCopy()
getCopy
in interface StepInterface
public long getErrors()
StepInterface
getErrors
in interface StepInterface
public void setErrors(long e)
StepInterface
setErrors
in interface StepInterface
e
- the number of errors to setpublic long getLinesRead()
getLinesRead
in interface StepInterface
public long incrementLinesRead()
public long decrementLinesRead()
public void setLinesRead(long newLinesReadValue)
newLinesReadValue
- the new number of lines read from previous stepspublic long getLinesInput()
getLinesInput
in interface StepInterface
public long incrementLinesInput()
public void setLinesInput(long newLinesInputValue)
newLinesInputValue
- the new number of lines read from an input source: database, file, socket, etc.public long getLinesOutput()
getLinesOutput
in interface StepInterface
public long incrementLinesOutput()
public void setLinesOutput(long newLinesOutputValue)
newLinesOutputValue
- the new number of lines written to an output target: database, file, socket, etc.public long getLinesWritten()
getLinesWritten
in interface StepInterface
public long incrementLinesWritten()
public long decrementLinesWritten()
public void setLinesWritten(long newLinesWrittenValue)
newLinesWrittenValue
- the new number of lines written to next stepspublic long getLinesUpdated()
getLinesUpdated
in interface StepInterface
public long incrementLinesUpdated()
public void setLinesUpdated(long newLinesUpdatedValue)
newLinesUpdatedValue
- the new number of lines updated in an output target: database, file, socket, etc.public long getLinesRejected()
getLinesRejected
in interface StepInterface
public long incrementLinesRejected()
public void setLinesRejected(long newLinesRejectedValue)
setLinesRejected
in interface StepInterface
newLinesRejectedValue
- lines number of lines rejected to an error handling steppublic long getLinesSkipped()
public long incrementLinesSkipped()
public void setLinesSkipped(long newLinesSkippedValue)
newLinesSkippedValue
- lines number of lines skippedpublic String getStepname()
StepInterface
getStepname
in interface StepInterface
public void setStepname(String stepname)
stepname
- the new stepnamepublic Trans getDispatcher()
public String getStatusDescription()
public StepMetaInterface getStepMetaInterface()
public void setStepMetaInterface(StepMetaInterface stepMetaInterface)
stepMetaInterface
- The stepMetaInterface to set.public StepDataInterface getStepDataInterface()
public void setStepDataInterface(StepDataInterface stepDataInterface)
stepDataInterface
- The stepDataInterface to set.public StepMeta getStepMeta()
getStepMeta
in interface StepInterface
public void setStepMeta(StepMeta stepMeta)
stepMeta
- The stepMeta to set.public TransMeta getTransMeta()
public void setTransMeta(TransMeta transMeta)
transMeta
- The transMeta to set.public Trans getTrans()
getTrans
in interface StepInterface
public void putRow(RowMetaInterface rowMeta, Object[] row) throws KettleStepException
putRow
in interface StepInterface
row
- The row to put to the destination rowset(s).rowMeta
- The row to send to the destinations stepsKettleStepException
public void putRowTo(RowMetaInterface rowMeta, Object[] row, RowSet rowSet) throws KettleStepException
rowMeta
- The row meta-data to put to the destination RowSet.row
- the data to put in the RowSetrowSet
- the RoWset to put the row into.KettleStepException
- In case something unexpected goes wrongpublic void handlePutRowTo(RowMetaInterface rowMeta, Object[] row, RowSet rowSet) throws KettleStepException
KettleStepException
public void putError(RowMetaInterface rowMeta, Object[] row, long nrErrors, String errorDescriptions, String fieldNames, String errorCodes) throws KettleStepException
rowMeta
- the row metarow
- the rownrErrors
- the nr errorserrorDescriptions
- the error descriptionsfieldNames
- the field nameserrorCodes
- the error codesKettleStepException
- the kettle step exceptionprotected void waitUntilTransformationIsStarted()
public Object[] getRow() throws KettleException
getRow
in interface StepInterface
KettleException
public void setRowHandler(RowHandler rowHandler)
handleGetRow()
and handlePutRow(RowMetaInterface, Object[])
public RowHandler getRowHandler()
protected void openRemoteInputStepSocketsOnce() throws KettleStepException
KettleStepException
protected void openRemoteOutputStepSocketsOnce() throws KettleStepException
KettleStepException
protected void safeModeChecking(RowMetaInterface row) throws KettleRowException
row
- the rowKettleRowException
- the kettle row exceptionpublic void identifyErrorOutput()
StepInterface
identifyErrorOutput
in interface StepInterface
public static void safeModeChecking(RowMetaInterface referenceRowMeta, RowMetaInterface rowMeta) throws KettleRowException
referenceRowMeta
- the reference row metarowMeta
- the row metaKettleRowException
- the kettle row exceptionpublic Object[] getRowFrom(RowSet rowSet) throws KettleStepException
rowSet
- the row setKettleStepException
- the kettle step exceptionpublic Object[] handleGetRowFrom(RowSet rowSet) throws KettleStepException
KettleStepException
protected void verifyInputDeadLock() throws KettleStepException
KettleStepException
public RowSet findInputRowSet(String sourceStep) throws KettleStepException
sourceStep
- the source stepKettleStepException
- the kettle step exceptionpublic RowSet findInputRowSet(String from, int fromcopy, String to, int tocopy)
from
- the fromfromcopy
- the fromcopyto
- the totocopy
- the tocopypublic RowSet findOutputRowSet(String targetStep) throws KettleStepException
targetStep
- the target stepKettleStepException
- the kettle step exceptionpublic RowSet findOutputRowSet(String from, int fromcopy, String to, int tocopy)
from
- fromcopy
- to
- tocopy
- public void setOutputDone()
StepInterface
setOutputDone
in interface StepInterface
public void dispatch()
Note that all rowsets input and output is already created by transformation itself. So in this place we will look and choose which rowsets will be used by this particular step.
We will collect all input rowsets and output rowsets so step will be able to read input data, and write to the output.
Steps can run in multiple copies, on in partitioned fashion. For this case we should take in account that in different cases we should take in account one to one, one to many and other cases properly.
public boolean isBasic()
public boolean isDetailed()
public boolean isDebug()
public boolean isRowLevel()
public void logMinimal(String message)
message
- the messagepublic void logMinimal(String message, Object... arguments)
message
- the messagearguments
- the argumentspublic void logBasic(String message)
message
- the messagepublic void logBasic(String message, Object... arguments)
message
- the messagearguments
- the argumentspublic void logDetailed(String message)
message
- the messagepublic void logDetailed(String message, Object... arguments)
message
- the messagearguments
- the argumentspublic void logDebug(String message)
message
- the messagepublic void logDebug(String message, Object... arguments)
message
- the messagearguments
- the argumentspublic void logRowlevel(String message)
message
- the messagepublic void logRowlevel(String message, Object... arguments)
message
- the messagearguments
- the argumentspublic void logError(String message)
message
- the messagepublic void logError(String message, Throwable e)
message
- the messagee
- the epublic void logError(String message, Object... arguments)
message
- the messagearguments
- the argumentspublic int getNextClassNr()
public boolean outputIsDone()
public void stopAll()
StepInterface
stopAll
in interface StepInterface
public boolean isStopped()
isStopped
in interface StepInterface
public boolean isRunning()
isRunning
in interface StepInterface
public boolean isPaused()
isPaused
in interface StepInterface
public void setStopped(boolean stopped)
setStopped
in interface StepInterface
stopped
- true if the step needs to be stoppedpublic void setSafeStopped(boolean stopped)
setSafeStopped
in interface StepInterface
stopped
- true if the step needs to be safe stoppedpublic boolean isSafeStopped()
isSafeStopped
in interface StepInterface
public void setRunning(boolean running)
StepInterface
setRunning
in interface StepInterface
running
- the running flag to setpublic void pauseRunning()
StepInterface
pauseRunning
in interface StepInterface
public void resumeRunning()
StepInterface
resumeRunning
in interface StepInterface
public void setPaused(boolean paused)
paused
- the new pausedpublic void setPaused(AtomicBoolean paused)
paused
- the new pausedpublic boolean isInitialising()
public void markStart()
StepInterface
markStart
in interface StepInterface
public void setInternalVariables()
public void markStop()
StepInterface
markStop
in interface StepInterface
public long getRuntime()
getRuntime
in interface StepInterface
public RowMetaAndData buildLog(String sname, int copynr, long lines_read, long lines_written, long lines_updated, long lines_skipped, long errors, Date start_date, Date end_date)
sname
- the snamecopynr
- the copynrlines_read
- the lines_readlines_written
- the lines_writtenlines_updated
- the lines_updatedlines_skipped
- the lines_skippederrors
- the errorsstart_date
- the start_dateend_date
- the end_datepublic static final RowMetaInterface getLogFields(String comm)
comm
- the commpublic int rowsetOutputSize()
rowsetOutputSize
in interface StepInterface
public int rowsetInputSize()
rowsetInputSize
in interface StepInterface
public void stopRunning(StepMetaInterface stepMetaInterface, StepDataInterface stepDataInterface) throws KettleException
stopRunning
in interface StepInterface
stepDataInterface
- The interface to the step data containing the connections, resultsets, open files, etc.stepMetaInterface
- The metadata that might be needed by the step to stop running.KettleException
- in case something goes wrong@Deprecated public void stopRunning()
stopRunning(StepMetaInterface, StepDataInterface)
public void logSummary()
public String getStepID()
getStepID
in interface StepInterface
public List<RowSet> getInputRowSets()
getInputRowSets
in interface StepInterface
public void addRowSetToInputRowSets(RowSet rowSet)
addRowSetToInputRowSets
in interface StepInterface
protected RowSet getFirstInputRowSet()
protected void clearInputRowSets()
protected void swapFirstInputRowSetIfExists(String stepName)
public void setInputRowSets(List<RowSet> inputRowSets)
inputRowSets
- The inputRowSets to set.public List<RowSet> getOutputRowSets()
getOutputRowSets
in interface StepInterface
public void addRowSetToOutputRowSets(RowSet rowSet)
addRowSetToOutputRowSets
in interface StepInterface
protected void clearOutputRowSets()
public void setOutputRowSets(List<RowSet> outputRowSets)
outputRowSets
- The outputRowSets to set.public boolean isDistributed()
public void setDistributed(boolean distributed)
distributed
- The distributed to set.public void addRowListener(RowListener rowListener)
StepInterface
addRowListener
in interface StepInterface
rowListener
- the rowlistener to addpublic void removeRowListener(RowListener rowListener)
StepInterface
removeRowListener
in interface StepInterface
rowListener
- the rowlistener to removepublic List<RowListener> getRowListeners()
getRowListeners
in interface StepInterface
public void addResultFile(ResultFile resultFile)
resultFile
- the result filepublic Map<String,ResultFile> getResultFiles()
getResultFiles
in interface StepInterface
public BaseStepData.StepExecutionStatus getStatus()
getStatus
in interface StepInterface
StepDataInterface
public String getPartitionID()
getPartitionID
in interface StepInterface
public void setPartitionID(String partitionID)
setPartitionID
in interface StepInterface
partitionID
- the partitionID to setpublic Map<String,BlockingRowSet> getPartitionTargets()
public void setPartitionTargets(Map<String,BlockingRowSet> partitionTargets)
partitionTargets
- the partitionTargets to setpublic int getRepartitioning()
public void setRepartitioning(int repartitioning)
setRepartitioning
in interface StepInterface
repartitioning
- the repartitioning type to setpublic boolean isPartitioned()
isPartitioned
in interface StepInterface
public void setPartitioned(boolean partitioned)
setPartitioned
in interface StepInterface
partitioned
- the partitioned to setprotected boolean checkFeedback(long lines)
lines
- the linespublic RowMetaInterface getInputRowMeta()
public void setInputRowMeta(RowMetaInterface rowMeta)
rowMeta
- the rowMeta to setpublic RowMetaInterface getErrorRowMeta()
public void setErrorRowMeta(RowMetaInterface errorRowMeta)
errorRowMeta
- the errorRowMeta to setpublic RowMetaInterface getPreviewRowMeta()
public void setPreviewRowMeta(RowMetaInterface previewRowMeta)
previewRowMeta
- the previewRowMeta to setpublic void copyVariablesFrom(VariableSpace space)
copyVariablesFrom
in interface VariableSpace
public String environmentSubstitute(String aString)
environmentSubstitute
in interface VariableSpace
public String[] environmentSubstitute(String[] aString)
environmentSubstitute
in interface VariableSpace
public String fieldSubstitute(String aString, RowMetaInterface rowMeta, Object[] rowData) throws KettleValueException
fieldSubstitute
in interface VariableSpace
KettleValueException
public VariableSpace getParentVariableSpace()
getParentVariableSpace
in interface VariableSpace
public void setParentVariableSpace(VariableSpace parent)
setParentVariableSpace
in interface VariableSpace
public String getVariable(String variableName, String defaultValue)
getVariable
in interface VariableSpace
public String getVariable(String variableName)
getVariable
in interface VariableSpace
public boolean getBooleanValueOfVariable(String variableName, boolean defaultValue)
getBooleanValueOfVariable
in interface VariableSpace
public void initializeVariablesFrom(VariableSpace parent)
initializeVariablesFrom
in interface VariableSpace
public String[] listVariables()
listVariables
in interface VariableSpace
public void setVariable(String variableName, String variableValue)
setVariable
in interface VariableSpace
public void shareVariablesWith(VariableSpace space)
shareVariablesWith
in interface VariableSpace
public void injectVariables(Map<String,String> prop)
injectVariables
in interface VariableSpace
public String getTypeId()
public int getSlaveNr()
public int getClusterSize()
public int getUniqueStepNrAcrossSlaves()
public int getUniqueStepCountAcrossSlaves()
public List<ServerSocket> getServerSockets()
public void setServerSockets(List<ServerSocket> serverSockets)
serverSockets
- the serverSockets to setpublic void setUsingThreadPriorityManagment(boolean usingThreadPriorityManagment)
setUsingThreadPriorityManagment
in interface StepInterface
usingThreadPriorityManagment
- set to true to actively manage priorities of step threadspublic boolean isUsingThreadPriorityManagment()
isUsingThreadPriorityManagment
in interface StepInterface
public void initBeforeStart() throws KettleStepException
More to the point: here we open remote output step sockets.
initBeforeStart
in interface StepInterface
KettleStepException
- In case there is an errorpublic List<StepListener> getStepListeners()
public void setStepListeners(List<StepListener> stepListeners)
stepListeners
- the stepListeners to setpublic boolean processRow(StepMetaInterface smi, StepDataInterface sdi) throws KettleException
StepInterface
processRow
in interface StepInterface
smi
- The steps metadata to work withsdi
- The steps temporary working data to work with (database connections, result sets, caches, temporary
variables, etc.)KettleException
public boolean canProcessOneRow()
StepInterface
For example, if a step has no input records but needs at least one to function, it will return false.
canProcessOneRow
in interface StepInterface
public void addStepListener(StepListener stepListener)
StepInterface
addStepListener
in interface StepInterface
stepListener
- The listener to add to the steppublic boolean isMapping()
isMapping
in interface StepInterface
public SocketRepository getSocketRepository()
public void setSocketRepository(SocketRepository socketRepository)
socketRepository
- the socketRepository to setpublic String getObjectName()
getObjectName
in interface LoggingObjectInterface
public LogChannelInterface getLogChannel()
getLogChannel
in interface HasLogChannelInterface
getLogChannel
in interface StepInterface
public String getFilename()
getFilename
in interface LoggingObjectInterface
public String getLogChannelId()
getLogChannelId
in interface LoggingObjectInterface
public ObjectId getObjectId()
getObjectId
in interface LoggingObjectInterface
public ObjectRevision getObjectRevision()
getObjectRevision
in interface LoggingObjectInterface
public LoggingObjectType getObjectType()
getObjectType
in interface LoggingObjectInterface
public LoggingObjectInterface getParent()
getParent
in interface LoggingObjectInterface
public RepositoryDirectory getRepositoryDirectory()
getRepositoryDirectory
in interface LoggingObjectInterface
public String getObjectCopy()
getObjectCopy
in interface LoggingObjectInterface
public LogLevel getLogLevel()
getLogLevel
in interface LoggingObjectInterface
public void setLogLevel(LogLevel logLevel)
logLevel
- the new log levelpublic static void closeQuietly(Closeable cl)
cl
- the object that can be closed.public String getContainerObjectId()
getContainerObjectId
in interface LoggingObjectInterface
public void setCarteObjectId(String containerObjectId)
containerObjectId
- the containerObjectId to setpublic void batchComplete() throws KettleException
StepInterface
batchComplete
in interface StepInterface
KettleException
- In case an error occurs during the processing of the batch of rows.public List<RemoteStep> getRemoteInputSteps()
public List<RemoteStep> getRemoteOutputSteps()
public Date getRegistrationDate()
getRegistrationDate
in interface LoggingObjectInterface
public boolean isGatheringMetrics()
isGatheringMetrics
in interface LoggingObjectInterface
public void setGatheringMetrics(boolean gatheringMetrics)
setGatheringMetrics
in interface LoggingObjectInterface
public boolean isForcingSeparateLogging()
isForcingSeparateLogging
in interface LoggingObjectInterface
public void setForcingSeparateLogging(boolean forcingSeparateLogging)
setForcingSeparateLogging
in interface LoggingObjectInterface
public Repository getRepository()
getRepository
in interface StepInterface
public void setRepository(Repository repository)
setRepository
in interface StepInterface
repository
- The repository used by the step to load and reference Kettle objects with at runtimepublic org.pentaho.metastore.api.IMetaStore getMetaStore()
getMetaStore
in interface StepInterface
public void setMetaStore(org.pentaho.metastore.api.IMetaStore metaStore)
StepInterface
setMetaStore
in interface StepInterface
metaStore
- The metastore to usepublic int getCurrentOutputRowSetNr()
getCurrentOutputRowSetNr
in interface StepInterface
public void setCurrentOutputRowSetNr(int index)
setCurrentOutputRowSetNr
in interface StepInterface
index
- Sets the index of the active (current) output row set to use.public int getCurrentInputRowSetNr()
getCurrentInputRowSetNr
in interface StepInterface
public void setCurrentInputRowSetNr(int index)
setCurrentInputRowSetNr
in interface StepInterface
index
- Sets the index of the active (current) input row set to use.public Map<String,Object> getExtensionDataMap()
getExtensionDataMap
in interface ExtensionDataInterface
Copyright © 2018 Hitachi Vantara. All rights reserved.