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

The following examples show how to use org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.annotation.JsonDeserialize. 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
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 #2
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 #3
Source File: JobDetailsInfo.java    From flink 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 #4
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 #5
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 #6
Source File: TaskManagerInfo.java    From flink 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 #7
Source File: TaskManagerInfo.java    From flink 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_TOTAL_RESOURCE) ResourceProfileInfo totalResource,
		@JsonProperty(FIELD_NAME_AVAILABLE_RESOURCE) ResourceProfileInfo freeResource,
		@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.totalResource = totalResource;
	this.freeResource = freeResource;
	this.hardwareDescription = Preconditions.checkNotNull(hardwareDescription);
}
 
Example #8
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_TOTAL_RESOURCE) ResourceProfileInfo totalResource,
		@JsonProperty(FIELD_NAME_AVAILABLE_RESOURCE) ResourceProfileInfo freeResource,
		@JsonProperty(FIELD_NAME_HARDWARE) HardwareDescription hardwareDescription,
		@JsonProperty(FIELD_NAME_METRICS) TaskManagerMetricsInfo taskManagerMetrics) {
	super(
		resourceId,
		address,
		dataPort,
		lastHeartbeat,
		numberSlots,
		numberAvailableSlots,
		totalResource,
		freeResource,
		hardwareDescription);

	this.taskManagerMetrics = Preconditions.checkNotNull(taskManagerMetrics);
}
 
Example #9
Source File: JobDetailsInfo.java    From flink 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 #10
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 #11
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 #12
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 #13
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 #14
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 #15
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 #16
Source File: JobVertexDetailsInfo.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobVertexDetailsInfo(
		@JsonDeserialize(using = JobVertexIDDeserializer.class) @JsonProperty(FIELD_NAME_VERTEX_ID) JobVertexID id,
		@JsonProperty(FIELD_NAME_VERTEX_NAME) String name,
		@JsonProperty(FIELD_NAME_PARALLELISM) int parallelism,
		@JsonProperty(FIELD_NAME_NOW) long now,
		@JsonProperty(FIELD_NAME_SUBTASKS) List<SubtaskExecutionAttemptDetailsInfo> subtasks) {
	this.id = checkNotNull(id);
	this.name = checkNotNull(name);
	this.parallelism = parallelism;
	this.now = now;
	this.subtasks = checkNotNull(subtasks);
}
 
Example #17
Source File: JobVertexTaskManagersInfo.java    From flink 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: CheckpointStatistics.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public CompletedCheckpointStatistics(
	@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_EXTERNAL_PATH) @Nullable String externalPath,
	@JsonProperty(FIELD_NAME_DISCARDED) boolean discarded) {
	super(
		id,
		status,
		savepoint,
		triggerTimestamp,
		latestAckTimestamp,
		stateSize,
		duration,
		alignmentBuffered,
		numSubtasks,
		numAckSubtasks,
		checkpointingStatisticsPerTask);

	this.externalPath = externalPath;
	this.discarded = discarded;
}
 
Example #19
Source File: CheckpointStatistics.java    From flink 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 #20
Source File: JobVertexTaskManagersInfo.java    From flink 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 #21
Source File: JobIdsWithStatusOverview.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobIdWithStatus(
	@JsonProperty(FIELD_NAME_JOB_ID) @JsonDeserialize(using = JobIDDeserializer.class) JobID jobId,
	@JsonProperty(FIELD_NAME_JOB_STATUS) JobStatus jobStatus) {
	this.jobId = Preconditions.checkNotNull(jobId);
	this.jobStatus = Preconditions.checkNotNull(jobStatus);
}
 
Example #22
Source File: CheckpointStatistics.java    From flink 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 #23
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 #24
Source File: CheckpointStatistics.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public CompletedCheckpointStatistics(
	@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_EXTERNAL_PATH) @Nullable String externalPath,
	@JsonProperty(FIELD_NAME_DISCARDED) boolean discarded) {
	super(
		id,
		status,
		savepoint,
		triggerTimestamp,
		latestAckTimestamp,
		stateSize,
		duration,
		alignmentBuffered,
		numSubtasks,
		numAckSubtasks,
		checkpointingStatisticsPerTask);

	this.externalPath = externalPath;
	this.discarded = discarded;
}
 
Example #25
Source File: JobAccumulatorsInfo.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobAccumulatorsInfo(
		@JsonProperty(FIELD_NAME_JOB_ACCUMULATORS) List<JobAccumulator> jobAccumulators,
		@JsonProperty(FIELD_NAME_USER_TASK_ACCUMULATORS) List<UserTaskAccumulator> userAccumulators,
		@JsonDeserialize(contentUsing = SerializedValueDeserializer.class) @JsonProperty(FIELD_NAME_SERIALIZED_USER_TASK_ACCUMULATORS) Map<String, SerializedValue<OptionalFailure<Object>>> serializedUserAccumulators) {
	this.jobAccumulators = Preconditions.checkNotNull(jobAccumulators);
	this.userAccumulators = Preconditions.checkNotNull(userAccumulators);
	this.serializedUserAccumulators = Preconditions.checkNotNull(serializedUserAccumulators);
}
 
Example #26
Source File: SubtasksAllAccumulatorsInfo.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public SubtasksAllAccumulatorsInfo(
	@JsonDeserialize(using = JobVertexIDDeserializer.class) @JsonProperty(FIELD_NAME_JOB_VERTEX_ID) JobVertexID jobVertexId,
	@JsonProperty(FIELD_NAME_PARALLELISM) int parallelism,
	@JsonProperty(FIELD_NAME_SUBTASKS) Collection<SubtaskAccumulatorsInfo> subtaskAccumulatorsInfos) {
	this.jobVertexId = Preconditions.checkNotNull(jobVertexId);
	this.parallelism = parallelism;
	this.subtaskAccumulatorsInfos = Preconditions.checkNotNull(subtaskAccumulatorsInfos);
}
 
Example #27
Source File: JobIdsWithStatusOverview.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobIdWithStatus(
	@JsonProperty(FIELD_NAME_JOB_ID) @JsonDeserialize(using = JobIDDeserializer.class) JobID jobId,
	@JsonProperty(FIELD_NAME_JOB_STATUS) JobStatus jobStatus) {
	this.jobId = Preconditions.checkNotNull(jobId);
	this.jobStatus = Preconditions.checkNotNull(jobStatus);
}
 
Example #28
Source File: JobDetailsInfo.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobDetailsInfo(
		@JsonDeserialize(using = JobIDDeserializer.class) @JsonProperty(FIELD_NAME_JOB_ID) JobID jobId,
		@JsonProperty(FIELD_NAME_JOB_NAME) String name,
		@JsonProperty(FIELD_NAME_IS_STOPPABLE) boolean isStoppable,
		@JsonProperty(FIELD_NAME_JOB_STATUS) JobStatus jobStatus,
		@JsonProperty(FIELD_NAME_START_TIME) long startTime,
		@JsonProperty(FIELD_NAME_END_TIME) long endTime,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_NOW) long now,
		@JsonProperty(FIELD_NAME_TIMESTAMPS) Map<JobStatus, Long> timestamps,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_INFOS) Collection<JobVertexDetailsInfo> jobVertexInfos,
		@JsonProperty(FIELD_NAME_JOB_VERTICES_PER_STATE) Map<ExecutionState, Integer> jobVerticesPerState,
		@JsonProperty(FIELD_NAME_JSON_PLAN) @JsonDeserialize(using = RawJsonDeserializer.class) String jsonPlan) {
	this.jobId = Preconditions.checkNotNull(jobId);
	this.name = Preconditions.checkNotNull(name);
	this.isStoppable = isStoppable;
	this.jobStatus = Preconditions.checkNotNull(jobStatus);
	this.startTime = startTime;
	this.endTime = endTime;
	this.duration = duration;
	this.now = now;
	this.timestamps = Preconditions.checkNotNull(timestamps);
	this.jobVertexInfos = Preconditions.checkNotNull(jobVertexInfos);
	this.jobVerticesPerState = Preconditions.checkNotNull(jobVerticesPerState);
	this.jsonPlan = Preconditions.checkNotNull(jsonPlan);
}
 
Example #29
Source File: JobExecutionResultResponseBody.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobExecutionResultResponseBody(
		@JsonProperty(value = "status", required = true) final QueueStatus status,
		@JsonProperty(value = "job-execution-result")
		@JsonDeserialize(using = JobResultDeserializer.class)
		@Nullable final JobResult jobExecutionResult) {
	this.status = requireNonNull(status);
	this.jobExecutionResult = jobExecutionResult;
}
 
Example #30
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;
}