org.apache.flink.shaded.jackson2.com.fasterxml.jackson.annotation.JsonCreator Java Examples

The following examples show how to use org.apache.flink.shaded.jackson2.com.fasterxml.jackson.annotation.JsonCreator. You can vote up the ones you like or vote down the ones you don't like, and go to the original project or source file by following the links above each example. You may check out the related API usage on the sidebar.
Example #1
Source File: CheckpointStatistics.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
private CheckpointStatistics(
		@JsonProperty(FIELD_NAME_ID) long id,
		@JsonProperty(FIELD_NAME_STATUS) CheckpointStatsStatus status,
		@JsonProperty(FIELD_NAME_IS_SAVEPOINT) boolean savepoint,
		@JsonProperty(FIELD_NAME_TRIGGER_TIMESTAMP) long triggerTimestamp,
		@JsonProperty(FIELD_NAME_LATEST_ACK_TIMESTAMP) long latestAckTimestamp,
		@JsonProperty(FIELD_NAME_STATE_SIZE) long stateSize,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) long alignmentBuffered,
		@JsonProperty(FIELD_NAME_NUM_SUBTASKS) int numSubtasks,
		@JsonProperty(FIELD_NAME_NUM_ACK_SUBTASKS) int numAckSubtasks,
		@JsonDeserialize(keyUsing = JobVertexIDKeyDeserializer.class) @JsonProperty(FIELD_NAME_TASKS) Map<JobVertexID, TaskCheckpointStatistics> checkpointStatisticsPerTask) {
	this.id = id;
	this.status = Preconditions.checkNotNull(status);
	this.savepoint = savepoint;
	this.triggerTimestamp = triggerTimestamp;
	this.latestAckTimestamp = latestAckTimestamp;
	this.stateSize = stateSize;
	this.duration = duration;
	this.alignmentBuffered = alignmentBuffered;
	this.numSubtasks = numSubtasks;
	this.numAckSubtasks = numAckSubtasks;
	this.checkpointStatisticsPerTask = Preconditions.checkNotNull(checkpointStatisticsPerTask);
}
 
Example #2
Source File: JobVertexDetailsInfo.java    From flink with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public VertexTaskDetail(
		@JsonProperty(FIELD_NAME_SUBTASK) int subtask,
		@JsonProperty(FIELD_NAME_STATUS) ExecutionState status,
		@JsonProperty(FIELD_NAME_ATTEMPT) int attempt,
		@JsonProperty(FIELD_NAME_HOST) String host,
		@JsonProperty(FIELD_NAME_START_TIME) long startTime,
		@JsonProperty(FIELD_NAME_END_TIME) long endTime,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_METRICS) IOMetricsInfo metrics) {
	this.subtask = subtask;
	this.status = checkNotNull(status);
	this.attempt = attempt;
	this.host = checkNotNull(host);
	this.startTime = startTime;
	this.startTimeCompatible = startTime;
	this.endTime = endTime;
	this.duration = duration;
	this.metrics = checkNotNull(metrics);
}
 
Example #3
Source File: TaskManagerDetailsInfo.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public TaskManagerDetailsInfo(
		@JsonDeserialize(using = ResourceIDDeserializer.class) @JsonProperty(FIELD_NAME_RESOURCE_ID) ResourceID resourceId,
		@JsonProperty(FIELD_NAME_ADDRESS) String address,
		@JsonProperty(FIELD_NAME_DATA_PORT) int dataPort,
		@JsonProperty(FIELD_NAME_LAST_HEARTBEAT) long lastHeartbeat,
		@JsonProperty(FIELD_NAME_NUMBER_SLOTS) int numberSlots,
		@JsonProperty(FIELD_NAME_NUMBER_AVAILABLE_SLOTS) int numberAvailableSlots,
		@JsonProperty(FIELD_NAME_HARDWARE) HardwareDescription hardwareDescription,
		@JsonProperty(FIELD_NAME_METRICS) TaskManagerMetricsInfo taskManagerMetrics) {
	super(
		resourceId,
		address,
		dataPort,
		lastHeartbeat,
		numberSlots,
		numberAvailableSlots,
		hardwareDescription);

	this.taskManagerMetrics = Preconditions.checkNotNull(taskManagerMetrics);
}
 
Example #4
Source File: TaskManagerInfo.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public TaskManagerInfo(
		@JsonDeserialize(using = ResourceIDDeserializer.class) @JsonProperty(FIELD_NAME_RESOURCE_ID) ResourceID resourceId,
		@JsonProperty(FIELD_NAME_ADDRESS) String address,
		@JsonProperty(FIELD_NAME_DATA_PORT) int dataPort,
		@JsonProperty(FIELD_NAME_LAST_HEARTBEAT) long lastHeartbeat,
		@JsonProperty(FIELD_NAME_NUMBER_SLOTS) int numberSlots,
		@JsonProperty(FIELD_NAME_NUMBER_AVAILABLE_SLOTS) int numberAvailableSlots,
		@JsonProperty(FIELD_NAME_HARDWARE) HardwareDescription hardwareDescription) {
	this.resourceId = Preconditions.checkNotNull(resourceId);
	this.address = Preconditions.checkNotNull(address);
	this.dataPort = dataPort;
	this.lastHeartbeat = lastHeartbeat;
	this.numberSlots = numberSlots;
	this.numberAvailableSlots = numberAvailableSlots;
	this.hardwareDescription = Preconditions.checkNotNull(hardwareDescription);
}
 
Example #5
Source File: JobVertexDetailsInfo.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public VertexTaskDetail(
		@JsonProperty(FIELD_NAME_SUBTASK) int subtask,
		@JsonProperty(FIELD_NAME_STATUS) ExecutionState status,
		@JsonProperty(FIELD_NAME_ATTEMPT) int attempt,
		@JsonProperty(FIELD_NAME_HOST) String host,
		@JsonProperty(FIELD_NAME_START_TIME) long startTime,
		@JsonProperty(FIELD_NAME_END_TIME) long endTime,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_METRICS) IOMetricsInfo metrics) {
	this.subtask = subtask;
	this.status = checkNotNull(status);
	this.attempt = attempt;
	this.host = checkNotNull(host);
	this.startTime = startTime;
	this.startTimeCompatible = startTime;
	this.endTime = endTime;
	this.duration = duration;
	this.metrics = checkNotNull(metrics);
}
 
Example #6
Source File: TaskCheckpointStatistics.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public TaskCheckpointStatistics(
		@JsonProperty(FIELD_NAME_ID) long checkpointId,
		@JsonProperty(FIELD_NAME_CHECKPOINT_STATUS) CheckpointStatsStatus checkpointStatus,
		@JsonProperty(FIELD_NAME_LATEST_ACK_TIMESTAMP) long latestAckTimestamp,
		@JsonProperty(FIELD_NAME_STATE_SIZE) long stateSize,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) long alignmentBuffered,
		@JsonProperty(FIELD_NAME_NUM_SUBTASKS) int numSubtasks,
		@JsonProperty(FIELD_NAME_NUM_ACK_SUBTASKS) int numAckSubtasks) {

	this.checkpointId = checkpointId;
	this.checkpointStatus = Preconditions.checkNotNull(checkpointStatus);
	this.latestAckTimestamp = latestAckTimestamp;
	this.stateSize = stateSize;
	this.duration = duration;
	this.alignmentBuffered = alignmentBuffered;
	this.numSubtasks = numSubtasks;
	this.numAckSubtasks = numAckSubtasks;
}
 
Example #7
Source File: SubtaskExecutionAttemptDetailsInfo.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public SubtaskExecutionAttemptDetailsInfo(
		@JsonProperty(FIELD_NAME_SUBTASK_INDEX) int subtaskIndex,
		@JsonProperty(FIELD_NAME_STATUS) ExecutionState status,
		@JsonProperty(FIELD_NAME_ATTEMPT) int attempt,
		@JsonProperty(FIELD_NAME_HOST) String host,
		@JsonProperty(FIELD_NAME_START_TIME) long startTime,
		@JsonProperty(FIELD_NAME_END_TIME) long endTime,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_METRICS) IOMetricsInfo ioMetricsInfo) {

	this.subtaskIndex = subtaskIndex;
	this.status = Preconditions.checkNotNull(status);
	this.attempt = attempt;
	this.host = Preconditions.checkNotNull(host);
	this.startTime = startTime;
	this.endTime = endTime;
	this.duration = duration;
	this.ioMetricsInfo = Preconditions.checkNotNull(ioMetricsInfo);
}
 
Example #8
Source File: IOMetricsInfo.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public IOMetricsInfo(
		@JsonProperty(FIELD_NAME_BYTES_READ) long bytesRead,
		@JsonProperty(FIELD_NAME_BYTES_READ_COMPLETE) boolean bytesReadComplete,
		@JsonProperty(FIELD_NAME_BYTES_WRITTEN) long bytesWritten,
		@JsonProperty(FIELD_NAME_BYTES_WRITTEN_COMPLETE) boolean bytesWrittenComplete,
		@JsonProperty(FIELD_NAME_RECORDS_READ) long recordsRead,
		@JsonProperty(FIELD_NAME_RECORDS_READ_COMPLETE) boolean recordsReadComplete,
		@JsonProperty(FIELD_NAME_RECORDS_WRITTEN) long recordsWritten,
		@JsonProperty(FIELD_NAME_RECORDS_WRITTEN_COMPLETE) boolean recordsWrittenComplete) {
	this.bytesRead = bytesRead;
	this.bytesReadComplete = bytesReadComplete;
	this.bytesWritten = bytesWritten;
	this.bytesWrittenComplete = bytesWrittenComplete;
	this.recordsRead = recordsRead;
	this.recordsReadComplete = recordsReadComplete;
	this.recordsWritten = recordsWritten;
	this.recordsWrittenComplete = recordsWrittenComplete;
}
 
Example #9
Source File: ClusterOverview.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public ClusterOverview(
		@JsonProperty(FIELD_NAME_TASKMANAGERS) int numTaskManagersConnected,
		@JsonProperty(FIELD_NAME_SLOTS_TOTAL) int numSlotsTotal,
		@JsonProperty(FIELD_NAME_SLOTS_AVAILABLE) int numSlotsAvailable,
		@JsonProperty(FIELD_NAME_JOBS_RUNNING) int numJobsRunningOrPending,
		@JsonProperty(FIELD_NAME_JOBS_FINISHED) int numJobsFinished,
		@JsonProperty(FIELD_NAME_JOBS_CANCELLED) int numJobsCancelled,
		@JsonProperty(FIELD_NAME_JOBS_FAILED) int numJobsFailed) {

	super(numJobsRunningOrPending, numJobsFinished, numJobsCancelled, numJobsFailed);
	
	this.numTaskManagersConnected = numTaskManagersConnected;
	this.numSlotsTotal = numSlotsTotal;
	this.numSlotsAvailable = numSlotsAvailable;
}
 
Example #10
Source File: CheckpointStatistics.java    From flink with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public PendingCheckpointStatistics(
	@JsonProperty(FIELD_NAME_ID) long id,
	@JsonProperty(FIELD_NAME_STATUS) CheckpointStatsStatus status,
	@JsonProperty(FIELD_NAME_IS_SAVEPOINT) boolean savepoint,
	@JsonProperty(FIELD_NAME_TRIGGER_TIMESTAMP) long triggerTimestamp,
	@JsonProperty(FIELD_NAME_LATEST_ACK_TIMESTAMP) long latestAckTimestamp,
	@JsonProperty(FIELD_NAME_STATE_SIZE) long stateSize,
	@JsonProperty(FIELD_NAME_DURATION) long duration,
	@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) long alignmentBuffered,
	@JsonProperty(FIELD_NAME_NUM_SUBTASKS) int numSubtasks,
	@JsonProperty(FIELD_NAME_NUM_ACK_SUBTASKS) int numAckSubtasks,
	@JsonDeserialize(keyUsing = JobVertexIDKeyDeserializer.class) @JsonProperty(FIELD_NAME_TASKS) Map<JobVertexID, TaskCheckpointStatistics> checkpointingStatisticsPerTask) {
	super(
		id,
		status,
		savepoint,
		triggerTimestamp,
		latestAckTimestamp,
		stateSize,
		duration,
		alignmentBuffered,
		numSubtasks,
		numAckSubtasks,
		checkpointingStatisticsPerTask);
}
 
Example #11
Source File: TaskCheckpointStatisticsWithSubtaskDetails.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public TaskCheckpointStatisticsWithSubtaskDetails(
		@JsonProperty(FIELD_NAME_ID) long checkpointId,
		@JsonProperty(FIELD_NAME_CHECKPOINT_STATUS) CheckpointStatsStatus checkpointStatus,
		@JsonProperty(FIELD_NAME_LATEST_ACK_TIMESTAMP) long latestAckTimestamp,
		@JsonProperty(FIELD_NAME_STATE_SIZE) long stateSize,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) long alignmentBuffered,
		@JsonProperty(FIELD_NAME_NUM_SUBTASKS) int numSubtasks,
		@JsonProperty(FIELD_NAME_NUM_ACK_SUBTASKS) int numAckSubtasks,
		@JsonProperty(FIELD_NAME_SUMMARY) Summary summary,
		@JsonProperty(FIELD_NAME_SUBTASKS_CHECKPOINT_STATISTICS) List<SubtaskCheckpointStatistics> subtaskCheckpointStatistics) {
	super(
		checkpointId,
		checkpointStatus,
		latestAckTimestamp,
		stateSize,
		duration,
		alignmentBuffered,
		numSubtasks,
		numAckSubtasks);

	this.summary = Preconditions.checkNotNull(summary);
	this.subtaskCheckpointStatistics = Preconditions.checkNotNull(subtaskCheckpointStatistics);
}
 
Example #12
Source File: CheckpointStatistics.java    From flink with Apache License 2.0 6 votes vote down vote up
@JsonCreator
private CheckpointStatistics(
		@JsonProperty(FIELD_NAME_ID) long id,
		@JsonProperty(FIELD_NAME_STATUS) CheckpointStatsStatus status,
		@JsonProperty(FIELD_NAME_IS_SAVEPOINT) boolean savepoint,
		@JsonProperty(FIELD_NAME_TRIGGER_TIMESTAMP) long triggerTimestamp,
		@JsonProperty(FIELD_NAME_LATEST_ACK_TIMESTAMP) long latestAckTimestamp,
		@JsonProperty(FIELD_NAME_STATE_SIZE) long stateSize,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) long alignmentBuffered,
		@JsonProperty(FIELD_NAME_NUM_SUBTASKS) int numSubtasks,
		@JsonProperty(FIELD_NAME_NUM_ACK_SUBTASKS) int numAckSubtasks,
		@JsonDeserialize(keyUsing = JobVertexIDKeyDeserializer.class) @JsonProperty(FIELD_NAME_TASKS) Map<JobVertexID, TaskCheckpointStatistics> checkpointStatisticsPerTask) {
	this.id = id;
	this.status = Preconditions.checkNotNull(status);
	this.savepoint = savepoint;
	this.triggerTimestamp = triggerTimestamp;
	this.latestAckTimestamp = latestAckTimestamp;
	this.stateSize = stateSize;
	this.duration = duration;
	this.alignmentBuffered = alignmentBuffered;
	this.numSubtasks = numSubtasks;
	this.numAckSubtasks = numAckSubtasks;
	this.checkpointStatisticsPerTask = Preconditions.checkNotNull(checkpointStatisticsPerTask);
}
 
Example #13
Source File: TaskManagerDetailsInfo.java    From flink with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public TaskManagerDetailsInfo(
		@JsonDeserialize(using = ResourceIDDeserializer.class) @JsonProperty(FIELD_NAME_RESOURCE_ID) ResourceID resourceId,
		@JsonProperty(FIELD_NAME_ADDRESS) String address,
		@JsonProperty(FIELD_NAME_DATA_PORT) int dataPort,
		@JsonProperty(FIELD_NAME_LAST_HEARTBEAT) long lastHeartbeat,
		@JsonProperty(FIELD_NAME_NUMBER_SLOTS) int numberSlots,
		@JsonProperty(FIELD_NAME_NUMBER_AVAILABLE_SLOTS) int numberAvailableSlots,
		@JsonProperty(FIELD_NAME_HARDWARE) HardwareDescription hardwareDescription,
		@JsonProperty(FIELD_NAME_METRICS) TaskManagerMetricsInfo taskManagerMetrics) {
	super(
		resourceId,
		address,
		dataPort,
		lastHeartbeat,
		numberSlots,
		numberAvailableSlots,
		hardwareDescription);

	this.taskManagerMetrics = Preconditions.checkNotNull(taskManagerMetrics);
}
 
Example #14
Source File: JobDetailsInfo.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public JobVertexDetailsInfo(
		@JsonDeserialize(using = JobVertexIDDeserializer.class) @JsonProperty(FIELD_NAME_JOB_VERTEX_ID) JobVertexID jobVertexID,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_NAME) String name,
		@JsonProperty(FIELD_NAME_PARALLELISM) int parallelism,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_STATE) ExecutionState executionState,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_START_TIME) long startTime,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_END_TIME) long endTime,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_DURATION) long duration,
		@JsonProperty(FIELD_NAME_TASKS_PER_STATE) Map<ExecutionState, Integer> tasksPerState,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_METRICS) IOMetricsInfo jobVertexMetrics) {
	this.jobVertexID = Preconditions.checkNotNull(jobVertexID);
	this.name = Preconditions.checkNotNull(name);
	this.parallelism = parallelism;
	this.executionState = Preconditions.checkNotNull(executionState);
	this.startTime = startTime;
	this.endTime = endTime;
	this.duration = duration;
	this.tasksPerState = Preconditions.checkNotNull(tasksPerState);
	this.jobVertexMetrics = Preconditions.checkNotNull(jobVertexMetrics);
}
 
Example #15
Source File: TaskCheckpointStatisticsWithSubtaskDetails.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public CheckpointDuration(
	@JsonProperty(FIELD_NAME_SYNCHRONOUS_DURATION) MinMaxAvgStatistics synchronousDuration,
	@JsonProperty(FIELD_NAME_ASYNCHRONOUS_DURATION) MinMaxAvgStatistics asynchronousDuration) {
	this.synchronousDuration = Preconditions.checkNotNull(synchronousDuration);
	this.asynchronousDuration = Preconditions.checkNotNull(asynchronousDuration);
}
 
Example #16
Source File: JobSubmitRequestBody.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public DistributedCacheFile(
	@JsonProperty(FIELD_NAME_ENTRY_NAME) String entryName,
	@JsonProperty(FIELD_NAME_FILE_NAME) String fileName) {
	this.entryName = entryName;
	this.fileName = fileName;
}
 
Example #17
Source File: JobVertexTaskManagersInfo.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobVertexTaskManagersInfo(
		@JsonDeserialize(using = JobVertexIDDeserializer.class) @JsonProperty(VERTEX_TASK_FIELD_ID) JobVertexID jobVertexID,
		@JsonProperty(VERTEX_TASK_FIELD_NAME) String name,
		@JsonProperty(VERTEX_TASK_FIELD_NOW) long now,
		@JsonProperty(VERTEX_TASK_FIELD_TASK_MANAGERS) Collection<TaskManagersInfo> taskManagerInfos) {
	this.jobVertexID = checkNotNull(jobVertexID);
	this.name = checkNotNull(name);
	this.now = now;
	this.taskManagerInfos = checkNotNull(taskManagerInfos);
}
 
Example #18
Source File: JobExceptionsInfo.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public ExecutionExceptionInfo(
	@JsonProperty(FIELD_NAME_EXCEPTION) String exception,
	@JsonProperty(FIELD_NAME_TASK) String task,
	@JsonProperty(FIELD_NAME_LOCATION) String location,
	@JsonProperty(FIELD_NAME_TIMESTAMP) long timestamp) {
	this.exception = Preconditions.checkNotNull(exception);
	this.task = Preconditions.checkNotNull(task);
	this.location = Preconditions.checkNotNull(location);
	this.timestamp = timestamp;
}
 
Example #19
Source File: JobExceptionsInfo.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobExceptionsInfo(
	@JsonProperty(FIELD_NAME_ROOT_EXCEPTION) String rootException,
	@JsonProperty(FIELD_NAME_TIMESTAMP) Long rootTimestamp,
	@JsonProperty(FIELD_NAME_ALL_EXCEPTIONS) List<ExecutionExceptionInfo> allExceptions,
	@JsonProperty(FIELD_NAME_TRUNCATED) boolean truncated) {
	this.rootException = rootException;
	this.rootTimestamp = rootTimestamp;
	this.allExceptions = Preconditions.checkNotNull(allExceptions);
	this.truncated = truncated;
}
 
Example #20
Source File: SubtaskCheckpointStatistics.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public CheckpointDuration(
		@JsonProperty(FIELD_NAME_SYNC_DURATION) long syncDuration,
		@JsonProperty(FIELD_NAME_ASYNC_DURATION) long asyncDuration) {
	this.syncDuration = syncDuration;
	this.asyncDuration = asyncDuration;
}
 
Example #21
Source File: CheckpointingStatistics.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public LatestCheckpoints(
		@JsonProperty(FIELD_NAME_COMPLETED) @Nullable CheckpointStatistics.CompletedCheckpointStatistics completedCheckpointStatistics,
		@JsonProperty(FIELD_NAME_SAVEPOINT) @Nullable CheckpointStatistics.CompletedCheckpointStatistics savepointStatistics,
		@JsonProperty(FIELD_NAME_FAILED) @Nullable CheckpointStatistics.FailedCheckpointStatistics failedCheckpointStatistics,
		@JsonProperty(FIELD_NAME_RESTORED) @Nullable RestoredCheckpointStatistics restoredCheckpointStatistics) {
	this.completedCheckpointStatistics = completedCheckpointStatistics;
	this.savepointStatistics = savepointStatistics;
	this.failedCheckpointStatistics = failedCheckpointStatistics;
	this.restoredCheckpointStatistics = restoredCheckpointStatistics;
}
 
Example #22
Source File: CheckpointingStatistics.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public Summary(
		@JsonProperty(FIELD_NAME_STATE_SIZE) MinMaxAvgStatistics stateSize,
		@JsonProperty(FIELD_NAME_DURATION) MinMaxAvgStatistics duration,
		@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) MinMaxAvgStatistics alignmentBuffered) {
	this.stateSize = stateSize;
	this.duration = duration;
	this.alignmentBuffered = alignmentBuffered;
}
 
Example #23
Source File: SubtaskCheckpointStatistics.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
private SubtaskCheckpointStatistics(
		@JsonProperty(FIELD_NAME_INDEX) int index,
		@JsonProperty(FIELD_NAME_CHECKPOINT_STATUS) String checkpointStatus) {
	this.index = index;
	this.checkpointStatus = checkpointStatus;
}
 
Example #24
Source File: JobVertexAccumulatorsInfo.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobVertexAccumulatorsInfo(
		@JsonProperty(FIELD_NAME_ID) String id,
		@JsonProperty(FIELD_NAME_USER_ACCUMULATORS) Collection<UserAccumulator> userAccumulatorList) {
	this.id = Preconditions.checkNotNull(id);
	this.userAccumulatorList = Preconditions.checkNotNull(userAccumulatorList);
}
 
Example #25
Source File: CheckpointingStatistics.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public RestoredCheckpointStatistics(
		@JsonProperty(FIELD_NAME_ID) long id,
		@JsonProperty(FIELD_NAME_RESTORE_TIMESTAMP) long restoreTimestamp,
		@JsonProperty(FIELD_NAME_IS_SAVEPOINT) boolean savepoint,
		@JsonProperty(FIELD_NAME_EXTERNAL_PATH) @Nullable String externalPath) {
	this.id = id;
	this.restoreTimestamp = restoreTimestamp;
	this.savepoint = savepoint;
	this.externalPath = externalPath;
}
 
Example #26
Source File: CheckpointStatistics.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public FailedCheckpointStatistics(
	@JsonProperty(FIELD_NAME_ID) long id,
	@JsonProperty(FIELD_NAME_STATUS) CheckpointStatsStatus status,
	@JsonProperty(FIELD_NAME_IS_SAVEPOINT) boolean savepoint,
	@JsonProperty(FIELD_NAME_TRIGGER_TIMESTAMP) long triggerTimestamp,
	@JsonProperty(FIELD_NAME_LATEST_ACK_TIMESTAMP) long latestAckTimestamp,
	@JsonProperty(FIELD_NAME_STATE_SIZE) long stateSize,
	@JsonProperty(FIELD_NAME_DURATION) long duration,
	@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) long alignmentBuffered,
	@JsonProperty(FIELD_NAME_NUM_SUBTASKS) int numSubtasks,
	@JsonProperty(FIELD_NAME_NUM_ACK_SUBTASKS) int numAckSubtasks,
	@JsonDeserialize(keyUsing = JobVertexIDKeyDeserializer.class) @JsonProperty(FIELD_NAME_TASKS) Map<JobVertexID, TaskCheckpointStatistics> checkpointingStatisticsPerTask,
	@JsonProperty(FIELD_NAME_FAILURE_TIMESTAMP) long failureTimestamp,
	@JsonProperty(FIELD_NAME_FAILURE_MESSAGE) @Nullable String failureMessage) {
	super(
		id,
		status,
		savepoint,
		triggerTimestamp,
		latestAckTimestamp,
		stateSize,
		duration,
		alignmentBuffered,
		numSubtasks,
		numAckSubtasks,
		checkpointingStatisticsPerTask);

	this.failureTimestamp = failureTimestamp;
	this.failureMessage = failureMessage;
}
 
Example #27
Source File: MinMaxAvgStatistics.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public MinMaxAvgStatistics(
	@JsonProperty(FIELD_NAME_MINIMUM) long minimum,
	@JsonProperty(FIELD_NAME_MAXIMUM) long maximum,
	@JsonProperty(FIELD_NAME_AVERAGE) long average) {
	this.minimum = minimum;
	this.maximum = maximum;
	this.average = average;
}
 
Example #28
Source File: JarPlanRequestBody.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
JarPlanRequestBody(
	@Nullable @JsonProperty(FIELD_NAME_ENTRY_CLASS) String entryClassName,
	@Nullable @JsonProperty(FIELD_NAME_PROGRAM_ARGUMENTS) String programArguments,
	@Nullable @JsonProperty(FIELD_NAME_PROGRAM_ARGUMENTS_LIST) List<String> programArgumentsList,
	@Nullable @JsonProperty(FIELD_NAME_PARALLELISM) Integer parallelism,
	@Nullable @JsonProperty(FIELD_NAME_JOB_ID) JobID jobId) {
	super(entryClassName, programArguments, programArgumentsList, parallelism, jobId);
}
 
Example #29
Source File: SavepointInfo.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public SavepointInfo(
		@JsonProperty(FIELD_NAME_LOCATION) @Nullable final String location,
		@JsonProperty(FIELD_NAME_FAILURE_CAUSE)
		@JsonDeserialize(using = SerializedThrowableDeserializer.class)
		@Nullable final SerializedThrowable failureCause) {
	checkArgument(
		location != null ^ failureCause != null,
		"Either location or failureCause must be set");

	this.location = location;
	this.failureCause = failureCause;
}
 
Example #30
Source File: RestServerEndpointITCase.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public TestResponse(
		@JsonProperty("id") int id,
		@JsonProperty("content") String content) {
	this.id = id;
	this.content = content;
}